2025.07.13 01:54:22.081685 [ 426 ] {} Context: Server was built in debug mode. It will work slowly. 2025.07.13 01:54:22.083041 [ 426 ] {} Context: ThreadFuzzer is enabled. Application will run slowly and unstable. 2025.07.13 01:54:23.920846 [ 445 ] {} CgroupsReader: Cannot find 'kernel' in '/sys/fs/cgroup/memory.stat' 2025.07.13 01:54:30.002618 [ 426 ] {} 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 01:54:30.011646 [ 426 ] {} KeeperLogStore: Removing all changelogs 2025.07.13 01:54:30.027574 [ 426 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.07.13 01:54:30.078323 [ 426 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.07.13 01:54:30.079562 [ 426 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.07.13 01:54:30.159347 [ 1106 ] {} RaftInstance: Election timeout, initiate leader election 2025.07.13 01:54:31.360092 [ 426 ] {} Access(local_directory): File /var/lib/clickhouse/access/users.list doesn't exist 2025.07.13 01:54:31.361203 [ 426 ] {} Access(local_directory): Recovering lists in directory /var/lib/clickhouse/access/ 2025.07.13 01:54:31.867975 [ 426 ] {} 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 01:54:31.886207 [ 426 ] {} 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 01:54:56.702682 [ 433 ] {65cd573a-aacb-4c20-b4f8-80342d91f072} 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 01:55:08.991267 [ 433 ] {2d7cc2b0-fcbf-4600-8e9f-33460f986636} 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 01:55:32.304136 [ 1112 ] {} RaftInstance: failed to accept a rpc connection due to error 125, Operation canceled 2025.07.13 01:55:41.493320 [ 1659 ] {} Context: Server was built in debug mode. It will work slowly. 2025.07.13 01:55:41.495023 [ 1659 ] {} Context: ThreadFuzzer is enabled. Application will run slowly and unstable. 2025.07.13 01:55:43.624446 [ 1686 ] {} CgroupsReader: Cannot find 'kernel' in '/sys/fs/cgroup/memory.stat' 2025.07.13 01:55:49.235254 [ 1659 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.07.13 01:55:49.316374 [ 1659 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.07.13 01:55:49.317535 [ 1659 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.07.13 01:55:49.413689 [ 2336 ] {} RaftInstance: Election timeout, initiate leader election 2025.07.13 01:55:50.982848 [ 1659 ] {} 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 01:55:50.994137 [ 1659 ] {} 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 01:57:40.072475 [ 1666 ] {fe5da227-75a5-4891-b87b-4b33ff423bed} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 68465.116638 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46924) (query 1, line 1) (in query: INSERT INTO test.hits_s3 SELECT * FROM datasets.hits_v1 SETTINGS enable_filesystem_cache_on_write_operations=0, max_insert_threads=16), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x0000000013ad84ab 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x0000000013ad77ec 5. /build/src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x000000001496af1f 6. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000168d1a5a 7. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0c24 8. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168cfe81 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 11. ? @ 0x00007fc4932e3ac3 12. ? @ 0x00007fc493375850 2025.07.13 01:58:02.783059 [ 1666 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 68465.116638 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x0000000013ad84ab 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x0000000013ad77ec 5. /build/src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x000000001496af1f 6. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000168d1a5a 7. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0c24 8. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168cfe81 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 11. ? @ 0x00007fc4932e3ac3 12. ? @ 0x00007fc493375850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x00000000168cf907 5. /build/src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000001680710e 6. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 11. ? @ 0x00007fc4932e3ac3 12. ? @ 0x00007fc493375850 2025.07.13 01:58:57.512188 [ 1668 ] {b5e729cb-5344-4c56-8fff-5e24e8f35703} executeQuery: Code: 241. DB::Exception: User memory limit exceeded: would use 9.18 GiB (attempt to allocate chunk of 2.86 MiB bytes), maximum: 9.18 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: (avg_value_size_hint = 119.57298278808594, avg_chars_size = 133.88757934570313, limit = 8192): (while reading column URL): (while reading from part store/78e/78ebf6a1-d987-4579-b3ec-00c1a087b1f3/201403_1_1_2/ in table datasets.hits_v1 (78ebf6a1-d987-4579-b3ec-00c1a087b1f3) located on disk __tmp_internal_262634248876485800814430204900764312493 of type web, from mark 432 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]:50932) (query 1, line 1) (in query: INSERT INTO test.hits SELECT * FROM datasets.hits_v1 SETTINGS enable_filesystem_cache_on_write_operations=0, max_insert_threads=16), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000000fb2de96 4. /build/src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2ca0a 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2c5bf 6. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2c5bf 7. /build/src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000fa9410c 8. /build/src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000000fa92864 9. /build/src/Common/PODArray.h:118: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000013c3922a 10. /build/src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000013ba04c3 11. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x00000000163ce98e 12. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000163ce0d2 13. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000163bc9b1 14. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000163c3d29 15. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x00000000163de7ba 16. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x00000000163dace0 17. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x0000000016d617ec 18. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5584 19. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 20. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 21. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 22. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 23. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 24. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 28. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 29. ? @ 0x00007fc4932e3ac3 30. ? @ 0x00007fc493375850 2025.07.13 01:59:22.972824 [ 1668 ] {} TCPHandler: Code: 241. DB::Exception: User memory limit exceeded: would use 9.18 GiB (attempt to allocate chunk of 2.86 MiB bytes), maximum: 9.18 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: (avg_value_size_hint = 119.57298278808594, avg_chars_size = 133.88757934570313, limit = 8192): (while reading column URL): (while reading from part store/78e/78ebf6a1-d987-4579-b3ec-00c1a087b1f3/201403_1_1_2/ in table datasets.hits_v1 (78ebf6a1-d987-4579-b3ec-00c1a087b1f3) located on disk __tmp_internal_262634248876485800814430204900764312493 of type web, from mark 432 with max_rows_to_read = 8192): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000000fb2de96 4. /build/src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2ca0a 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2c5bf 6. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2c5bf 7. /build/src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000fa9410c 8. /build/src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000000fa92864 9. /build/src/Common/PODArray.h:118: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000013c3922a 10. /build/src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000013ba04c3 11. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x00000000163ce98e 12. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000163ce0d2 13. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000163bc9b1 14. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000163c3d29 15. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x00000000163de7ba 16. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x00000000163dace0 17. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x0000000016d617ec 18. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5584 19. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 20. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 21. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 22. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 23. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 24. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 28. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 29. ? @ 0x00007fc4932e3ac3 30. ? @ 0x00007fc493375850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d2752 6. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 12. ? @ 0x00007fc4932e3ac3 13. ? @ 0x00007fc493375850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168cfe81 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007fc4932e3ac3 11. ? @ 0x00007fc493375850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x00000000168cf907 5. /build/src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000001680710e 6. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 11. ? @ 0x00007fc4932e3ac3 12. ? @ 0x00007fc493375850 2025.07.13 02:00:42.193080 [ 1666 ] {bce3177e-2641-47b8-b48e-4058f7c23e3f} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 79011.566563 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34510) (query 1, line 1) (in query: INSERT INTO test.visits SELECT * FROM datasets.visits_v1 SETTINGS enable_filesystem_cache_on_write_operations=0, max_insert_threads=16), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, unsigned long const&) @ 0x00000000144421ab 4. /build/src/Interpreters/ProcessList.cpp:519: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000001496a7fb 5. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x000000001496af0d 6. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000168d1a5a 7. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0c24 8. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168cfe81 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 11. ? @ 0x00007fc4932e3ac3 12. ? @ 0x00007fc493375850 2025.07.13 02:00:43.023309 [ 1686 ] {} CgroupsReader: Cannot find 'kernel' in '/sys/fs/cgroup/memory.stat' (skipped 5686 similar messages) 2025.07.13 02:00:52.451371 [ 1666 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 79011.566563 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, unsigned long const&) @ 0x00000000144421ab 4. /build/src/Interpreters/ProcessList.cpp:519: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000001496a7fb 5. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x000000001496af0d 6. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000168d1a5a 7. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0c24 8. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168cfe81 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 11. ? @ 0x00007fc4932e3ac3 12. ? @ 0x00007fc493375850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x00000000168cf907 5. /build/src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000001680710e 6. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 11. ? @ 0x00007fc4932e3ac3 12. ? @ 0x00007fc493375850 2025.07.13 02:00:59.702591 [ 3534 ] {} Context: Server was built in debug mode. It will work slowly. 2025.07.13 02:00:59.704076 [ 3534 ] {} Context: ThreadFuzzer is enabled. Application will run slowly and unstable. 2025.07.13 02:01:01.652437 [ 3552 ] {} CgroupsReader: Cannot find 'kernel' in '/sys/fs/cgroup/memory.stat' 2025.07.13 02:01:07.901707 [ 3534 ] {} 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:01:07.941066 [ 3534 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.07.13 02:01:07.942129 [ 3534 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.07.13 02:01:08.010009 [ 4213 ] {} RaftInstance: Election timeout, initiate leader election 2025.07.13 02:01:10.556156 [ 3534 ] {} Context: Server logging level is set to 'test' and performance is degraded. This cannot be used in production. 2025.07.13 02:01:10.563767 [ 3534 ] {} 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:01:10.679278 [ 3534 ] {} 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:01:55.446336 [ 4879 ] {2a584c17-5ee0-4c90-afd2-fcd5d39c5c39} executeQuery: Code: 107. DB::Exception: File /var/lib/clickhouse/store/926/9266bff7-11dc-41b8-884e-de63bc4000ff//data.TSV doesn't exist. (FILE_DOESNT_EXIST) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57800) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Storages/StorageFile.cpp:1630: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000015caf8eb 5. /build/src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000148b600e 6. /build/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&) @ 0x00000000148ad029 7. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 8. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 10. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:01:55.469516 [ 4879 ] {} TCPHandler: Code: 107. DB::Exception: File /var/lib/clickhouse/store/926/9266bff7-11dc-41b8-884e-de63bc4000ff//data.TSV doesn't exist. (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Storages/StorageFile.cpp:1630: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000015caf8eb 5. /build/src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000148b600e 6. /build/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&) @ 0x00000000148ad029 7. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 8. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 10. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:01:58.247597 [ 5121 ] {e907d60e-2ab8-4689-b6a0-3c1a21ddb2b3} 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]:57890) (comment: 01825_type_json_insert_select.sql) (query 1, line 3) (in query: SET allow_experimental_object_type = 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:01:58.303197 [ 5121 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:01:59.244052 [ 4871 ] {dd2719f9-c127-424f-ab54-1690c812911b} executeQuery: Code: 47. DB::Exception: Compound identifier 'lambda.nested' cannot be resolved as function. In scope WITH x -> (x + 1) AS lambda SELECT lambda.nested(1). (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57878) (comment: 02385_analyzer_aliases_compound_expression.sql) (query 5, line 9) (in query: WITH (x -> x + 1) AS lambda SELECT lambda.nested(1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, char const*&&, String&&) @ 0x0000000013f68a8b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1278: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000013f480ee 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000013f4856d 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2751: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4d5f8 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:01:59.287035 [ 4871 ] {} TCPHandler: Code: 47. DB::Exception: Compound identifier 'lambda.nested' cannot be resolved as function. In scope WITH x -> (x + 1) AS lambda SELECT lambda.nested(1). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, char const*&&, String&&) @ 0x0000000013f68a8b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1278: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000013f480ee 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000013f4856d 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2751: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4d5f8 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:01:59.831812 [ 4922 ] {8403aba6-af6e-444f-b785-7b7a522a9ac0} executeQuery: Code: 36. DB::Exception: Cannot sleep infinite, very large or negative amount of time (not implemented). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41678) (comment: 02915_sleep_large_uint.sql) (query 1, line 1) (in query: SELECT sleep(3.40282e+44);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/sleep.cpp:119: DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)0>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000000e5e85bb 5. /build/src/Functions/sleep.cpp:100: DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)0>::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e5e7faf 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 10. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013ec18ac 11. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013ec09aa 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016b30052 13. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016cdda71 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000130d8a1a 15. /build/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>>&) @ 0x00000000148a05bd 16. /build/src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000001489a16a 17. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 19. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:01:59.885456 [ 4922 ] {} TCPHandler: Code: 36. DB::Exception: Cannot sleep infinite, very large or negative amount of time (not implemented). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/sleep.cpp:119: DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)0>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000000e5e85bb 5. /build/src/Functions/sleep.cpp:100: DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)0>::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e5e7faf 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 10. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013ec18ac 11. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013ec09aa 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016b30052 13. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016cdda71 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000130d8a1a 15. /build/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>>&) @ 0x00000000148a05bd 16. /build/src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000001489a16a 17. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 19. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:02:00.078325 [ 4922 ] {1351fcb0-cf31-41b5-a2cc-10ebf9c8be67} executeQuery: Code: 36. DB::Exception: Cannot sleep infinite, very large or negative amount of time (not implemented). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41678) (comment: 02915_sleep_large_uint.sql) (query 2, line 2) (in query: SELECT sleep((pow(2, 64) / 1000000) - 1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/sleep.cpp:119: DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)0>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000000e5e85bb 5. /build/src/Functions/sleep.cpp:100: DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)0>::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e5e7faf 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 10. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013ec18ac 11. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013ec09aa 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016b30052 13. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016cdda71 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000130d8a1a 15. /build/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>>&) @ 0x00000000148a05bd 16. /build/src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000001489a16a 17. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 19. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:02:00.097508 [ 4922 ] {} TCPHandler: Code: 36. DB::Exception: Cannot sleep infinite, very large or negative amount of time (not implemented). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/sleep.cpp:119: DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)0>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000000e5e85bb 5. /build/src/Functions/sleep.cpp:100: DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)0>::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e5e7faf 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 10. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013ec18ac 11. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013ec09aa 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016b30052 13. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016cdda71 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000130d8a1a 15. /build/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>>&) @ 0x00000000148a05bd 16. /build/src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000001489a16a 17. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 19. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:02:00.172687 [ 3543 ] {3c603202-e0c6-4315-8c5f-af14bc51fd9f} 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]:57854) (comment: 01523_date_time_compare_with_date_literal.sql) (query 7, line 10) (in query: SELECT * FROM test WHERE timestamp != '2020-10-15' ORDER BY timestamp;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbdb1ad 7. /build/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) @ 0x000000001631ac2d 8. /build/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) @ 0x0000000016d5067d 9. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x0000000016d4f5b9 10. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x0000000016d4f3b2 11. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d571cc 12. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016cf6870 13. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:02:00.188120 [ 3543 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbdb1ad 7. /build/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) @ 0x000000001631ac2d 8. /build/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) @ 0x0000000016d5067d 9. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x0000000016d4f5b9 10. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x0000000016d4f3b2 11. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d571cc 12. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016cf6870 13. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:02:00.447358 [ 4922 ] {1498d452-f6ee-4c35-a136-8c68f3416c0c} executeQuery: Code: 36. DB::Exception: Cannot sleep infinite, very large or negative amount of time (not implemented). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41678) (comment: 02915_sleep_large_uint.sql) (query 3, line 3) (in query: SELECT sleepEachRow(184467440737095516) from numbers(10000);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/sleep.cpp:119: DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000000e5e9072 5. /build/src/Functions/sleep.cpp:100: DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)1>::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e5e8a4f 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 10. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013ec18ac 11. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013ec09aa 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016b30052 13. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016cdda71 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000130d8a1a 15. /build/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>>&) @ 0x00000000148a05bd 16. /build/src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000001489a16a 17. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 19. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:02:00.500492 [ 4922 ] {} TCPHandler: Code: 36. DB::Exception: Cannot sleep infinite, very large or negative amount of time (not implemented). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/sleep.cpp:119: DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000000e5e9072 5. /build/src/Functions/sleep.cpp:100: DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)1>::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e5e8a4f 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 10. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013ec18ac 11. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013ec09aa 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016b30052 13. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016cdda71 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000130d8a1a 15. /build/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>>&) @ 0x00000000148a05bd 16. /build/src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000001489a16a 17. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 19. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:02:00.910731 [ 4871 ] {aff266c1-ba91-435c-9241-692d07612846} executeQuery: Code: 47. DB::Exception: Compound identifier 't1.nested' cannot be resolved as table expression. In scope SELECT * FROM (SELECT 1) AS t1, t1.nested AS t2. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57878) (comment: 02385_analyzer_aliases_compound_expression.sql) (query 10, line 19) (in query: SELECT * FROM (SELECT 1) AS t1, t1.nested AS t2;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, char const*&&, String&&) @ 0x0000000013f68a8b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1278: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000013f480ee 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000013f4856d 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4364: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62ab9 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:02:00.942989 [ 4871 ] {} TCPHandler: Code: 47. DB::Exception: Compound identifier 't1.nested' cannot be resolved as table expression. In scope SELECT * FROM (SELECT 1) AS t1, t1.nested AS t2. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, char const*&&, String&&) @ 0x0000000013f68a8b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1278: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000013f480ee 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000013f4856d 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4364: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62ab9 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:02:01.082154 [ 5117 ] {a5f9a67a-5da6-46e5-b9a7-f17d50f77198} 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]:57816) (comment: 01640_marks_corruption_regression.sql) (query 6, line 33) (in query: -- Reset marks cache DETACH TABLE adaptive_table;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Databases/DatabaseReplicated.cpp:1106: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013cc3688 5. /build/src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc384b 6. /build/src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833287 7. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 8. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 9. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:02:01.143179 [ 4871 ] {ccd977b4-829b-49f0-9e81-9f5c4f6f719c} executeQuery: Code: 47. DB::Exception: Compound identifier 't1.nested' cannot be resolved as table expression. In scope SELECT * FROM t1.nested AS t2, (SELECT 1) AS t1. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57878) (comment: 02385_analyzer_aliases_compound_expression.sql) (query 11, line 21) (in query: SELECT * FROM t1.nested AS t2, (SELECT 1) AS t1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, char const*&&, String&&) @ 0x0000000013f68a8b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1278: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000013f480ee 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000013f4856d 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4364: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62ab9 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:02:01.164682 [ 4871 ] {} TCPHandler: Code: 47. DB::Exception: Compound identifier 't1.nested' cannot be resolved as table expression. In scope SELECT * FROM t1.nested AS t2, (SELECT 1) AS t1. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, char const*&&, String&&) @ 0x0000000013f68a8b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1278: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000013f480ee 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000013f4856d 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4364: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62ab9 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:02:01.209116 [ 4922 ] {a9a5011d-4632-42d4-911a-e5b1074ecc22} executeQuery: Code: 160. DB::Exception: The maximum sleep time is 4294967295 microseconds. Requested: 2147483648000000 microseconds: while executing 'FUNCTION sleepEachRow(_CAST(2147483648._Float64, 'Float64'_String) :: 1) -> sleepEachRow(_CAST(2147483648._Float64, 'Float64'_String)) UInt8 : 2'. (TOO_SLOW) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41678) (comment: 02915_sleep_large_uint.sql) (query 5, line 5) (in query: SELECT sleepEachRow(pow(2, 31)) from numbers(9007199254740992) settings function_sleep_max_microseconds_per_block = 8589934592000000000;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, unsigned long&) @ 0x0000000009fbd92b 4. /build/src/Functions/sleep.cpp:131: DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000000e5e9106 5. /build/src/Functions/sleep.cpp:106: DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e5e8a2c 6. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 7. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 10. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 11. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 12. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 13. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 17. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 18. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 19. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 22. ? @ 0x00007f7210eb6ac3 23. ? @ 0x00007f7210f48850 2025.07.13 02:02:01.260386 [ 5117 ] {} TCPHandler: Code: 80. DB::Exception: DETACH TABLE is not allowed for Replicated databases. Use DETACH TABLE PERMANENTLY or SYSTEM RESTART REPLICA or set database_replicated_always_detach_permanently to 1. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Databases/DatabaseReplicated.cpp:1106: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013cc3688 5. /build/src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc384b 6. /build/src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833287 7. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 8. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 9. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:02:01.330201 [ 4922 ] {} TCPHandler: Code: 160. DB::Exception: The maximum sleep time is 4294967295 microseconds. Requested: 2147483648000000 microseconds: while executing 'FUNCTION sleepEachRow(_CAST(2147483648._Float64, 'Float64'_String) :: 1) -> sleepEachRow(_CAST(2147483648._Float64, 'Float64'_String)) UInt8 : 2'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, unsigned long&) @ 0x0000000009fbd92b 4. /build/src/Functions/sleep.cpp:131: DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000000e5e9106 5. /build/src/Functions/sleep.cpp:106: DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e5e8a2c 6. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 7. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 10. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 11. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 12. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 13. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 17. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 18. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 19. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 22. ? @ 0x00007f7210eb6ac3 23. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:02:01.517635 [ 5018 ] {} TCPHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000013779f8b 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000137794b8 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778c58 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168167bf 10. /build/src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000001680ff45 11. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:02:01.673754 [ 5018 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x0000000016810069 5. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 6. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 2025.07.13 02:02:01.687572 [ 3542 ] {2e01bde3-ff04-4a5c-9765-d888a73e39e2} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000013779f8b 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000137794b8 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778c58 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168167bf 10. /build/src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000001680ff45 11. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41664) (comment: 00697_in_subquery_shard.sql) (query 5, line 8) (in query: SELECT dummy IN (SELECT 0) FROM remote('127.0.0.1', system.one);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fb80677 3. /build/src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x00000000166f5247 4. /build/src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000166fc432 5. /build/src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001673a5f3 6. /build/src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013af6952 7. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013af679a 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013af64e1 2025.07.13 02:02:01.729722 [ 3542 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000013779f8b 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000137794b8 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778c58 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168167bf 10. /build/src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000001680ff45 11. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fb80677 3. /build/src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x00000000166f5247 4. /build/src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000166fc432 5. /build/src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001673a5f3 6. /build/src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013af6952 7. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013af679a 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013af64e1 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:02:05.280159 [ 5128 ] {3300e1d0-f73e-466d-8eb8-77799c752008} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=787, jobs=778). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41794) (comment: 01017_in_unconvertible_complex_type.sql) (query 5, line 8) (in query: select [toUInt8(0)] in [-1];), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbdd1d3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd751c 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 9. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 10. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:02:05.327741 [ 5128 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=787, jobs=778). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbdd1d3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd751c 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 9. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 10. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:02:06.098725 [ 4871 ] {ed747951-fef2-49fc-9104-b256bce4c4dc} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 18.32 MiB (attempt to allocate chunk of 9.16 MiB bytes), maximum: 9.54 MiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41748) (comment: 01019_Buffer_and_max_memory_usage.sql) (query 11, line 33) (in query: INSERT INTO buffer_ SELECT toUInt64(number) FROM system.numbers LIMIT toUInt64(10e6+1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000000fb2de96 4. /build/src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2ca0a 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2c5bf 6. /build/src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000fa9410c 7. /build/src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000000fa92c7f 8. /build/src/Common/PODArray.h:152: void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::reserve_exact<>(unsigned long) @ 0x000000000a154727 9. /build/src/Interpreters/Squashing.cpp:175: DB::Squashing::squash(std::vector>&&, DB::CollectionOfDerivedItems&&) @ 0x00000000149caec9 10. /build/src/Interpreters/Squashing.cpp:45: DB::Squashing::squash(DB::Chunk&&) @ 0x00000000149ca482 11. /build/src/Processors/Transforms/ApplySquashingTransform.h:35: DB::ApplySquashingTransform::onConsume(DB::Chunk) @ 0x00000000148569d9 12. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 14. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 20. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168cfe81 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:02:06.192401 [ 4871 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 18.32 MiB (attempt to allocate chunk of 9.16 MiB bytes), maximum: 9.54 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000000fb2de96 4. /build/src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2ca0a 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2c5bf 6. /build/src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000fa9410c 7. /build/src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000000fa92c7f 8. /build/src/Common/PODArray.h:152: void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::reserve_exact<>(unsigned long) @ 0x000000000a154727 9. /build/src/Interpreters/Squashing.cpp:175: DB::Squashing::squash(std::vector>&&, DB::CollectionOfDerivedItems&&) @ 0x00000000149caec9 10. /build/src/Interpreters/Squashing.cpp:45: DB::Squashing::squash(DB::Chunk&&) @ 0x00000000149ca482 11. /build/src/Processors/Transforms/ApplySquashingTransform.h:35: DB::ApplySquashingTransform::onConsume(DB::Chunk) @ 0x00000000148569d9 12. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 14. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 20. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168cfe81 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x00000000168cf907 5. /build/src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000001680710e 6. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 2025.07.13 02:02:06.389978 [ 4961 ] {8ced5406-fe13-4ed8-890e-c5c756b953d8} executeQuery: Code: 57. DB::Exception: Table test_11.optimize_sorting already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02377_optimize_sorting_by_input_stream_properties.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_11.optimize_sorting UUID 'd7b96b8d-dc89-4534-b424-0253b0ba796b' (`a` UInt64, `b` UInt64, `c` UInt64) ENGINE = MergeTree ORDER BY (a, b) SETTINGS index_granularity = 22787, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.7018798589706421, replace_long_file_name_to_hash = false, max_file_name_length = 91, min_bytes_for_full_part_storage = 503677559, compact_parts_max_bytes_to_buffer = 76264794, compact_parts_max_granules_to_buffer = 62, compact_parts_merge_max_bytes_to_prefetch_part = 33456358, merge_max_block_size = 23169, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 7832313588, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 9651558160, index_granularity_bytes = 16587903, 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 = true, cache_populated_by_fetch = false, marks_compress_block_size = 87454, primary_key_compress_block_size = 16215, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 12. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:02:06.543343 [ 4961 ] {8ced5406-fe13-4ed8-890e-c5c756b953d8} executeQuery: Code: 57. DB::Exception: Table test_11.optimize_sorting already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41694) (comment: 02377_optimize_sorting_by_input_stream_properties.sql) (query 8, line 13) (in query: CREATE TABLE optimize_sorting (`a` UInt64, `b` UInt64, `c` UInt64) ENGINE = MergeTree ORDER BY (a, b) SETTINGS index_granularity = 22787, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.7018798589706421, replace_long_file_name_to_hash = false, max_file_name_length = 91, min_bytes_for_full_part_storage = 503677559, compact_parts_max_bytes_to_buffer = 76264794, compact_parts_max_granules_to_buffer = 62, compact_parts_merge_max_bytes_to_prefetch_part = 33456358, merge_max_block_size = 23169, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 7832313588, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 9651558160, index_granularity_bytes = 16587903, 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 = true, cache_populated_by_fetch = false, marks_compress_block_size = 87454, primary_key_compress_block_size = 16215, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 12. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:02:06.565729 [ 4961 ] {} TCPHandler: Code: 57. DB::Exception: Table test_11.optimize_sorting already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 12. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:02:09.744168 [ 4870 ] {89cb0ead-743b-400d-9b7d-038f7fd23e02} executeQuery: Code: 36. DB::Exception: Data type have to be specified for column `value` to add. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41892) (comment: 01079_alter_default_zookeeper_long.sql) (query 4, line 15) (in query: -- Cannot add column without type ALTER TABLE alter_default ADD COLUMN value DEFAULT '10';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/AlterCommands.cpp:1442: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015c15db3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fcff4 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:02:09.766873 [ 4870 ] {} TCPHandler: Code: 36. DB::Exception: Data type have to be specified for column `value` to add. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/AlterCommands.cpp:1442: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015c15db3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fcff4 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:02:15.689245 [ 4879 ] {9640626f-1f46-4979-9147-80ba88b1623e} executeQuery: Code: 117. DB::Exception: JSON object contains duplicate key 'b': (while reading the value of key a): (at row 1) : While executing JSONEachRowRowInputFormat. (INCORRECT_DATA) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44096) (comment: 03284_json_object_as_tuple_duplicate_keys.sql) (query 1, line 1) (in query: select * from format(JSONEachRow, 'a Tuple(b UInt32)', '{"a" : {"b" : 1, "b" : 2}}');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/DataTypes/Serializations/SerializationTuple.cpp:391: void DB::SerializationTuple::deserializeTupleJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)>(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)&&) const::'lambda'()::operator()() const @ 0x0000000013c4b0e2 5. /build/src/DataTypes/Serializations/SerializationTuple.cpp:90: void DB::SerializationTuple::deserializeTupleJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)>(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)&&) const @ 0x0000000013c4959e 6. /build/src/DataTypes/Serializations/SerializationTuple.cpp:524: DB::SerializationTuple::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013c44353 7. /build/src/DataTypes/Serializations/SerializationNullable.cpp:841: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000013bf4fab 8. /build/src/Formats/JSONUtils.cpp:295: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x0000000016888f98 9. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:136: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x00000000169efe97 10. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:194: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x00000000169f00f4 11. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:228: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000169f054b 12. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016940972 13. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 14. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 15. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 16. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 17. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 18. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 19. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 20. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000168e1018 21. /build/src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000001175705f 22. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000130d4903 23. /build/src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000143537f2 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3da49 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 28. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 29. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 31. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 2025.07.13 02:02:15.710621 [ 4879 ] {} TCPHandler: Code: 117. DB::Exception: JSON object contains duplicate key 'b': (while reading the value of key a): (at row 1) : While executing JSONEachRowRowInputFormat. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/DataTypes/Serializations/SerializationTuple.cpp:391: void DB::SerializationTuple::deserializeTupleJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)>(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)&&) const::'lambda'()::operator()() const @ 0x0000000013c4b0e2 5. /build/src/DataTypes/Serializations/SerializationTuple.cpp:90: void DB::SerializationTuple::deserializeTupleJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)>(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)&&) const @ 0x0000000013c4959e 6. /build/src/DataTypes/Serializations/SerializationTuple.cpp:524: DB::SerializationTuple::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013c44353 7. /build/src/DataTypes/Serializations/SerializationNullable.cpp:841: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000013bf4fab 8. /build/src/Formats/JSONUtils.cpp:295: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x0000000016888f98 9. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:136: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x00000000169efe97 10. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:194: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x00000000169f00f4 11. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:228: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000169f054b 12. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016940972 13. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 14. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 15. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 16. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 17. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 18. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 19. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 20. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000168e1018 21. /build/src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000001175705f 22. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000130d4903 23. /build/src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000143537f2 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3da49 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 28. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 29. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 31. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 2025.07.13 02:02:15.880411 [ 4879 ] {e13263d8-55c2-46da-8812-9d1148564aee} executeQuery: Code: 117. DB::Exception: JSON object contains duplicate key 'b': (while reading the value of key a): (at row 1) : While executing JSONEachRowRowInputFormat. (INCORRECT_DATA) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44096) (comment: 03284_json_object_as_tuple_duplicate_keys.sql) (query 2, line 2) (in query: select * from format(JSONEachRow, '{"a" : {"b" : 1, "b" : 2}}');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/DataTypes/Serializations/SerializationTuple.cpp:391: void DB::SerializationTuple::deserializeTupleJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)>(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)&&) const::'lambda'()::operator()() const @ 0x0000000013c4b0e2 5. /build/src/DataTypes/Serializations/SerializationTuple.cpp:90: void DB::SerializationTuple::deserializeTupleJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)>(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)&&) const @ 0x0000000013c4959e 6. /build/src/DataTypes/Serializations/SerializationTuple.cpp:524: DB::SerializationTuple::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013c44353 7. /build/src/DataTypes/Serializations/SerializationNullable.cpp:841: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000013bf4fab 8. /build/src/Formats/JSONUtils.cpp:295: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x0000000016888f98 9. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:136: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x00000000169efe97 10. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:194: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x00000000169f00f4 11. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:228: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000169f054b 12. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016940972 13. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 14. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 15. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 16. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 17. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 18. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 19. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 20. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000168e1018 21. /build/src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000001175705f 22. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000130d4903 23. /build/src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000143537f2 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3da49 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 28. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 29. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 31. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 2025.07.13 02:02:15.895279 [ 4879 ] {} TCPHandler: Code: 117. DB::Exception: JSON object contains duplicate key 'b': (while reading the value of key a): (at row 1) : While executing JSONEachRowRowInputFormat. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/DataTypes/Serializations/SerializationTuple.cpp:391: void DB::SerializationTuple::deserializeTupleJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)>(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)&&) const::'lambda'()::operator()() const @ 0x0000000013c4b0e2 5. /build/src/DataTypes/Serializations/SerializationTuple.cpp:90: void DB::SerializationTuple::deserializeTupleJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)>(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)&&) const @ 0x0000000013c4959e 6. /build/src/DataTypes/Serializations/SerializationTuple.cpp:524: DB::SerializationTuple::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013c44353 7. /build/src/DataTypes/Serializations/SerializationNullable.cpp:841: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000013bf4fab 8. /build/src/Formats/JSONUtils.cpp:295: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x0000000016888f98 9. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:136: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x00000000169efe97 10. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:194: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x00000000169f00f4 11. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:228: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000169f054b 12. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016940972 13. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 14. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 15. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 16. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 17. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 18. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 19. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 20. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000168e1018 21. /build/src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000001175705f 22. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000130d4903 23. /build/src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000143537f2 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3da49 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 28. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 29. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 31. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 2025.07.13 02:02:16.042163 [ 4879 ] {cf515727-f515-4956-9fa0-c70472a889bd} executeQuery: Code: 117. DB::Exception: JSON object contains duplicate key 'b': (while reading the value of key a): (at row 1) : While executing JSONEachRowRowInputFormat. (INCORRECT_DATA) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44096) (comment: 03284_json_object_as_tuple_duplicate_keys.sql) (query 3, line 3) (in query: select * from format(JSONEachRow, '{"a" : {"b" : 1, "b" : 2, "b" : 3}, "c" : 42}');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/DataTypes/Serializations/SerializationTuple.cpp:391: void DB::SerializationTuple::deserializeTupleJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)>(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)&&) const::'lambda'()::operator()() const @ 0x0000000013c4b0e2 5. /build/src/DataTypes/Serializations/SerializationTuple.cpp:90: void DB::SerializationTuple::deserializeTupleJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)>(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)&&) const @ 0x0000000013c4959e 6. /build/src/DataTypes/Serializations/SerializationTuple.cpp:524: DB::SerializationTuple::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013c44353 7. /build/src/DataTypes/Serializations/SerializationNullable.cpp:841: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000013bf4fab 8. /build/src/Formats/JSONUtils.cpp:295: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x0000000016888f98 9. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:136: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x00000000169efe97 10. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:194: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x00000000169f00f4 11. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:228: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000169f054b 12. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016940972 13. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 14. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 15. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 16. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 17. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 18. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 19. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 20. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000168e1018 21. /build/src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000001175705f 22. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000130d4903 23. /build/src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000143537f2 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3da49 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 28. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 29. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 31. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 2025.07.13 02:02:16.057815 [ 4879 ] {} TCPHandler: Code: 117. DB::Exception: JSON object contains duplicate key 'b': (while reading the value of key a): (at row 1) : While executing JSONEachRowRowInputFormat. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/DataTypes/Serializations/SerializationTuple.cpp:391: void DB::SerializationTuple::deserializeTupleJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)>(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)&&) const::'lambda'()::operator()() const @ 0x0000000013c4b0e2 5. /build/src/DataTypes/Serializations/SerializationTuple.cpp:90: void DB::SerializationTuple::deserializeTupleJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)>(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)&&) const @ 0x0000000013c4959e 6. /build/src/DataTypes/Serializations/SerializationTuple.cpp:524: DB::SerializationTuple::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013c44353 7. /build/src/DataTypes/Serializations/SerializationNullable.cpp:841: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000013bf4fab 8. /build/src/Formats/JSONUtils.cpp:295: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x0000000016888f98 9. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:136: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x00000000169efe97 10. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:194: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x00000000169f00f4 11. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:228: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000169f054b 12. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016940972 13. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 14. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 15. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 16. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 17. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 18. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 19. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 20. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000168e1018 21. /build/src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000001175705f 22. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000130d4903 23. /build/src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000143537f2 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3da49 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 28. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 29. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 31. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 2025.07.13 02:02:16.445161 [ 5987 ] {0719cffb-d132-4e08-83e9-1d41a0df54d9} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 8.91 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]:41906) (comment: 01781_token_extractor_buffer_overflow.sql) (query 4, line 5) (in query: INSERT INTO bloom_filter SELECT number, 'yyy,uuu' FROM numbers(1024);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x000000000fb2dd39 4. /build/src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2cb67 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2c5bf 6. /build/src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000fa9410c 7. /build/src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000000fa92864 8. /build/src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000000fb7acd2 9. /build/src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000001785cb0a 10. /build/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&) @ 0x00000000162f9e4b 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartWriterOnDisk::initSkipIndices() @ 0x00000000162fb184 12. /build/src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:205: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x00000000162fa753 13. /build/src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x00000000162f46ad 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x00000000162e6c97 15. /build/src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000016217e8d 16. /build/src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000001643ef43 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x00000000163309fc 18. /build/src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001632dc9f 19. /build/src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x00000000165911f4 20. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016c130f3 21. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 23. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 25. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 26. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 27. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 28. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 29. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168cfe81 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 31. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 2025.07.13 02:02:16.499603 [ 5987 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 8.91 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x000000000fb2dd39 4. /build/src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2cb67 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2c5bf 6. /build/src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000fa9410c 7. /build/src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000000fa92864 8. /build/src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000000fb7acd2 9. /build/src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000001785cb0a 10. /build/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&) @ 0x00000000162f9e4b 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartWriterOnDisk::initSkipIndices() @ 0x00000000162fb184 12. /build/src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:205: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x00000000162fa753 13. /build/src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x00000000162f46ad 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x00000000162e6c97 15. /build/src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000016217e8d 16. /build/src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000001643ef43 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x00000000163309fc 18. /build/src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001632dc9f 19. /build/src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x00000000165911f4 20. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016c130f3 21. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 23. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 25. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 26. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 27. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 28. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 29. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168cfe81 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 31. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x00000000168cf907 5. /build/src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000001680710e 6. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 2025.07.13 02:02:16.584437 [ 4879 ] {dbcfdf54-2b3d-484e-8496-9f3da0ece310} executeQuery: Code: 117. DB::Exception: JSON object contains duplicate key 'b': (while reading the value of key a): (at row 1) : While executing JSONEachRowRowInputFormat. (INCORRECT_DATA) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44096) (comment: 03284_json_object_as_tuple_duplicate_keys.sql) (query 6, line 6) (in query: select * from format(JSONEachRow, '{"a" : {"b" : 1, "b" : "Hello"}}');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/DataTypes/Serializations/SerializationTuple.cpp:391: void DB::SerializationTuple::deserializeTupleJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)>(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)&&) const::'lambda'()::operator()() const @ 0x0000000013c4b0e2 5. /build/src/DataTypes/Serializations/SerializationTuple.cpp:90: void DB::SerializationTuple::deserializeTupleJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)>(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)&&) const @ 0x0000000013c4959e 6. /build/src/DataTypes/Serializations/SerializationTuple.cpp:524: DB::SerializationTuple::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013c44353 7. /build/src/DataTypes/Serializations/SerializationNullable.cpp:841: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000013bf4fab 8. /build/src/Formats/JSONUtils.cpp:295: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x0000000016888f98 9. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:136: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x00000000169efe97 10. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:194: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x00000000169f00f4 11. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:228: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000169f054b 12. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016940972 13. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 14. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 15. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 16. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 17. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 18. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 19. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 20. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000168e1018 21. /build/src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000001175705f 22. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000130d4903 23. /build/src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000143537f2 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3da49 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 28. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 29. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 31. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 2025.07.13 02:02:16.607648 [ 4879 ] {} TCPHandler: Code: 117. DB::Exception: JSON object contains duplicate key 'b': (while reading the value of key a): (at row 1) : While executing JSONEachRowRowInputFormat. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/DataTypes/Serializations/SerializationTuple.cpp:391: void DB::SerializationTuple::deserializeTupleJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)>(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)&&) const::'lambda'()::operator()() const @ 0x0000000013c4b0e2 5. /build/src/DataTypes/Serializations/SerializationTuple.cpp:90: void DB::SerializationTuple::deserializeTupleJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)>(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)&&) const @ 0x0000000013c4959e 6. /build/src/DataTypes/Serializations/SerializationTuple.cpp:524: DB::SerializationTuple::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013c44353 7. /build/src/DataTypes/Serializations/SerializationNullable.cpp:841: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000013bf4fab 8. /build/src/Formats/JSONUtils.cpp:295: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x0000000016888f98 9. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:136: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x00000000169efe97 10. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:194: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x00000000169f00f4 11. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:228: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000169f054b 12. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016940972 13. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 14. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 15. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 16. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 17. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 18. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 19. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 20. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000168e1018 21. /build/src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000001175705f 22. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000130d4903 23. /build/src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000143537f2 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3da49 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 28. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 29. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 31. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 2025.07.13 02:02:16.871945 [ 4879 ] {81a04346-aca1-4205-8c5c-a3936cbde5b3} executeQuery: Code: 117. DB::Exception: JSON object contains duplicate key 'b': (while reading the value of key a): (at row 1) : While executing JSONEachRowRowInputFormat. (INCORRECT_DATA) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44096) (comment: 03284_json_object_as_tuple_duplicate_keys.sql) (query 8, line 8) (in query: select * from format(JSONEachRow, '{"a" : {"b" : 1, "b" : {"c" : "Hello"}}}');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/DataTypes/Serializations/SerializationTuple.cpp:391: void DB::SerializationTuple::deserializeTupleJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)>(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)&&) const::'lambda'()::operator()() const @ 0x0000000013c4b0e2 5. /build/src/DataTypes/Serializations/SerializationTuple.cpp:90: void DB::SerializationTuple::deserializeTupleJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)>(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)&&) const @ 0x0000000013c4959e 6. /build/src/DataTypes/Serializations/SerializationTuple.cpp:524: DB::SerializationTuple::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013c44353 7. /build/src/DataTypes/Serializations/SerializationNullable.cpp:841: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000013bf4fab 8. /build/src/Formats/JSONUtils.cpp:295: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x0000000016888f98 9. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:136: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x00000000169efe97 10. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:194: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x00000000169f00f4 11. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:228: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000169f054b 12. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016940972 13. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 14. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 15. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 16. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 17. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 18. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 19. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 20. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000168e1018 21. /build/src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000001175705f 22. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000130d4903 23. /build/src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000143537f2 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3da49 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 28. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 29. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 31. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 2025.07.13 02:02:16.879062 [ 4879 ] {} TCPHandler: Code: 117. DB::Exception: JSON object contains duplicate key 'b': (while reading the value of key a): (at row 1) : While executing JSONEachRowRowInputFormat. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/DataTypes/Serializations/SerializationTuple.cpp:391: void DB::SerializationTuple::deserializeTupleJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)>(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)&&) const::'lambda'()::operator()() const @ 0x0000000013c4b0e2 5. /build/src/DataTypes/Serializations/SerializationTuple.cpp:90: void DB::SerializationTuple::deserializeTupleJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)>(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)&&) const @ 0x0000000013c4959e 6. /build/src/DataTypes/Serializations/SerializationTuple.cpp:524: DB::SerializationTuple::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013c44353 7. /build/src/DataTypes/Serializations/SerializationNullable.cpp:841: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000013bf4fab 8. /build/src/Formats/JSONUtils.cpp:295: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x0000000016888f98 9. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:136: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x00000000169efe97 10. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:194: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x00000000169f00f4 11. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:228: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000169f054b 12. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016940972 13. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 14. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 15. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 16. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 17. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 18. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 19. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 20. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000168e1018 21. /build/src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000001175705f 22. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000130d4903 23. /build/src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000143537f2 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3da49 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 28. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 29. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 31. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 2025.07.13 02:02:17.141013 [ 4871 ] {518f3014-8dd0-44c3-8aab-18784d567b9d} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 01019_Buffer_and_max_memory_usage.sql) (in query: /* ddl_entry=query-0000000006 */ TRUNCATE TABLE test_7bp7jx8k.buffer_), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/IStorage.cpp:171: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015c3ce9a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833683 6. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 7. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 12. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 14. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 15. /build/src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833287 16. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 17. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 18. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 19. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:02:17.200750 [ 4871 ] {518f3014-8dd0-44c3-8aab-18784d567b9d} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41748) (comment: 01019_Buffer_and_max_memory_usage.sql) (query 19, line 49) (in query: DROP TABLE buffer_;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/IStorage.cpp:171: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015c3ce9a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833683 6. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 7. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 12. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 14. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 15. /build/src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833287 16. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 17. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 18. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 19. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:02:17.223170 [ 4871 ] {} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/IStorage.cpp:171: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015c3ce9a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833683 6. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 7. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 12. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 14. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 15. /build/src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833287 16. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 17. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 18. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 19. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:02:17.322136 [ 5018 ] {1cdbe927-142e-47dc-96aa-ec742201852c} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `y` in scope y >= 20. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41782) (comment: 02703_row_policies_for_database_combination.sh) (query 50, line 74) (in query: SELECT * FROM 02703_unexpected_columns;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000013f69e39 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f3a889 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f3112e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Planner/Utils.cpp:473: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013f071ef 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000148b45f3 12. /build/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&) @ 0x00000000148ad029 13. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 14. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:02:17.362267 [ 5018 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `y` in scope y >= 20. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000013f69e39 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f3a889 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f3112e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Planner/Utils.cpp:473: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013f071ef 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000148b45f3 12. /build/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&) @ 0x00000000148ad029 13. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 14. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:02:17.516251 [ 5073 ] {57bc6ec6-ef73-4b53-9ec8-4e579ba54d56} StorageBuffer (test_7bp7jx8k.buffer_): Destination table test_7bp7jx8k.null_ doesn't exist. Block of data is discarded. 2025.07.13 02:02:17.569523 [ 5117 ] {a3ebc74f-3800-4f7b-bf98-2460f835b28d} executeQuery: Code: 48. DB::Exception: MergeJoinAlgorithm is not implemented for strictness Semi. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44122) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::JoinStrictness&) @ 0x0000000016b4c42b 4. /build/src/Processors/Transforms/MergeJoinTransform.cpp:446: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(DB::JoinKind, DB::JoinStrictness, DB::TableJoin::JoinOnClause const&, std::vector> const&, unsigned long) @ 0x0000000016b44f2f 5. /build/src/Processors/Transforms/MergeJoinTransform.cpp:470: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(std::shared_ptr, std::vector> const&, unsigned long) @ 0x0000000016b4532c 6. /build/src/Processors/Merges/IMergingTransform.h:112: DB::MergeJoinTransform::MergeJoinTransform(std::shared_ptr, std::vector> const&, DB::Block const&, unsigned long, unsigned long) @ 0x0000000016b4bab5 7. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::QueryPipelineBuilder::joinPipelinesYShaped(std::unique_ptr>, std::unique_ptr>, std::shared_ptr, DB::Block const&, unsigned long, std::vector, std::allocator>>*) @ 0x0000000013accc22 8. /build/src/Processors/QueryPlan/JoinStep.cpp:114: DB::JoinStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d01d35 9. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 14. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 15. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 20. ? @ 0x00007f7210eb6ac3 21. ? @ 0x00007f7210f48850 2025.07.13 02:02:17.597917 [ 5117 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::JoinStrictness&) @ 0x0000000016b4c42b 4. /build/src/Processors/Transforms/MergeJoinTransform.cpp:446: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(DB::JoinKind, DB::JoinStrictness, DB::TableJoin::JoinOnClause const&, std::vector> const&, unsigned long) @ 0x0000000016b44f2f 5. /build/src/Processors/Transforms/MergeJoinTransform.cpp:470: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(std::shared_ptr, std::vector> const&, unsigned long) @ 0x0000000016b4532c 6. /build/src/Processors/Merges/IMergingTransform.h:112: DB::MergeJoinTransform::MergeJoinTransform(std::shared_ptr, std::vector> const&, DB::Block const&, unsigned long, unsigned long) @ 0x0000000016b4bab5 7. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::QueryPipelineBuilder::joinPipelinesYShaped(std::unique_ptr>, std::unique_ptr>, std::shared_ptr, DB::Block const&, unsigned long, std::vector, std::allocator>>*) @ 0x0000000013accc22 8. /build/src/Processors/QueryPlan/JoinStep.cpp:114: DB::JoinStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d01d35 9. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 14. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 15. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 20. ? @ 0x00007f7210eb6ac3 21. ? @ 0x00007f7210f48850 2025.07.13 02:02:17.783648 [ 4871 ] {57bc6ec6-ef73-4b53-9ec8-4e579ba54d56} executeQuery: Code: 80. DB::Exception: It's not initial query. ON CLUSTER is not allowed for Replicated database. (INCORRECT_QUERY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33846) (comment: 01019_Buffer_and_max_memory_usage.sql) (in query: DROP DATABASE IF EXISTS test_7bp7jx8k SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Databases/DatabaseReplicated.cpp:1126: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc4abd 5. /build/src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833287 6. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 7. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/InterpreterDropQuery.cpp:579: DB::InterpreterDropQuery::executeDropQuery(DB::ASTDropQuery::Kind, std::shared_ptr, std::shared_ptr, DB::StorageID const&, bool, bool, bool) @ 0x0000000014836de0 10. /build/src/Storages/StorageMaterializedView.cpp:480: DB::StorageMaterializedView::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015d3f996 11. /build/src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833683 12. /build/src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835a47 13. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 14. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 15. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 17. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 18. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 19. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 20. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 2025.07.13 02:02:17.788304 [ 4871 ] {57bc6ec6-ef73-4b53-9ec8-4e579ba54d56} DynamicQueryHandler: Code: 80. DB::Exception: It's not initial query. ON CLUSTER is not allowed for Replicated database. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Databases/DatabaseReplicated.cpp:1126: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc4abd 5. /build/src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833287 6. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 7. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/InterpreterDropQuery.cpp:579: DB::InterpreterDropQuery::executeDropQuery(DB::ASTDropQuery::Kind, std::shared_ptr, std::shared_ptr, DB::StorageID const&, bool, bool, bool) @ 0x0000000014836de0 10. /build/src/Storages/StorageMaterializedView.cpp:480: DB::StorageMaterializedView::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015d3f996 11. /build/src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833683 12. /build/src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835a47 13. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 14. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 15. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 17. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 18. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 19. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 20. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:02:18.407918 [ 5117 ] {4b1fe0cf-4396-43a6-b9dd-c3f507549870} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:d9ec4b09-3843-40aa-bd91-07b25307402c'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33862) (comment: 03321_join_on_is_null_lowcardinality.sql) (in query: CREATE DATABASE IF NOT EXISTS test_30vrf7q5 ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:02:18.418512 [ 5117 ] {4b1fe0cf-4396-43a6-b9dd-c3f507549870} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:d9ec4b09-3843-40aa-bd91-07b25307402c'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:02:18.799249 [ 4912 ] {8ae67455-96de-4625-bcfa-9f3d71fe2b4e} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:139abed8-b232-4f1a-a142-6bba92bbd50e'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33878) (comment: 01012_select_limit_x_0.sql) (in query: CREATE DATABASE IF NOT EXISTS test_5mmvzs7z ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:02:18.821004 [ 4912 ] {8ae67455-96de-4625-bcfa-9f3d71fe2b4e} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:139abed8-b232-4f1a-a142-6bba92bbd50e'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:02:18.956291 [ 4879 ] {174a4e70-a2f2-454c-9f7f-e9d3ab6f727d} executeQuery: Code: 507. DB::Exception: Sharding key is not deterministic. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44146) (comment: 01528_allow_nondeterministic_optimize_skip_unused_shards.sql) (query 5, line 8) (in query: select * from dist_01528 where dummy = 2;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Storages/StorageDistributed.cpp:1562: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000015c80558 5. /build/src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000015c7f18d 6. /build/src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000148b5e3b 7. /build/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&) @ 0x00000000148ad029 8. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 9. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:02:18.980930 [ 4879 ] {} TCPHandler: Code: 507. DB::Exception: Sharding key is not deterministic. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Storages/StorageDistributed.cpp:1562: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000015c80558 5. /build/src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000015c7f18d 6. /build/src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000148b5e3b 7. /build/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&) @ 0x00000000148ad029 8. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 9. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:02:19.251415 [ 6166 ] {87c6307b-9f2b-41f4-9c2f-997aa38733d7} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:ce1c4190-da00-4f0d-876d-a163b580e9a0'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39438) (comment: 02896_dwarf_format.sh) (in query: CREATE DATABASE IF NOT EXISTS test_5j2r1aih ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:02:19.255496 [ 6166 ] {87c6307b-9f2b-41f4-9c2f-997aa38733d7} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:ce1c4190-da00-4f0d-876d-a163b580e9a0'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:02:19.448486 [ 5987 ] {00c97acd-9cda-4729-8aae-019b04638f1e} 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]:44144) (comment: 02973_analyzer_join_use_nulls_column_not_found.sql) (query 7, line 39) (in query: WITH a AS ( SELECT 0 AS key, 'a' AS acol ), b AS ( SELECT 2 AS key ) SELECT a.key FROM b LEFT JOIN a ON 1 LEFT JOIN a AS a1 ON 1 ;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/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&) @ 0x00000000148d464b 5. /build/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&) @ 0x00000000148afcbb 6. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 7. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 9. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:02:19.484962 [ 5987 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/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&) @ 0x00000000148d464b 5. /build/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&) @ 0x00000000148afcbb 6. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 7. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 9. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:02:19.532803 [ 4871 ] {c9b8f585-4c49-4724-8f21-f7f864701ea0} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:54df7eb4-8cf2-4f97-8cf6-9b03d876a698'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39456) (comment: 00481_create_view_for_null.sql) (in query: CREATE DATABASE IF NOT EXISTS test_pp3b7j8w ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:02:19.560945 [ 4871 ] {c9b8f585-4c49-4724-8f21-f7f864701ea0} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:54df7eb4-8cf2-4f97-8cf6-9b03d876a698'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:02:19.858713 [ 5998 ] {16b34c6a-5861-4690-9e07-c9be2af44d93} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:1472a286-1948-4afc-baab-777d9fde3c04'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39478) (comment: 00305_http_and_readonly.sh) (in query: CREATE DATABASE IF NOT EXISTS test_j3odyil6 ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:02:19.871781 [ 4871 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778c58 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168167bf 10. /build/src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000001680ff45 11. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:02:19.880507 [ 4871 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x0000000016810069 5. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 6. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 2025.07.13 02:02:19.880310 [ 5998 ] {16b34c6a-5861-4690-9e07-c9be2af44d93} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:1472a286-1948-4afc-baab-777d9fde3c04'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:02:20.287594 [ 5998 ] {3bfa30dc-7fce-426c-b1f7-a71bd2698ea4} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:2cf86508-431e-473a-b758-c3c7a27546f8'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39490) (comment: 02252_executable_user_defined_function_short_circuit.sql) (in query: CREATE DATABASE IF NOT EXISTS test_8mkl6m6h ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:02:20.293848 [ 5998 ] {3bfa30dc-7fce-426c-b1f7-a71bd2698ea4} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:2cf86508-431e-473a-b758-c3c7a27546f8'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:02:20.604435 [ 4871 ] {90b5026b-4400-4719-ba0c-4ef93545819c} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:e3e67ecd-bdfe-4c9d-bf57-d1061f7a7e6f'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39502) (comment: 03033_create_as_copies_comment.sql) (in query: CREATE DATABASE IF NOT EXISTS test_0gsr3sh6 ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:02:20.610279 [ 4871 ] {90b5026b-4400-4719-ba0c-4ef93545819c} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:e3e67ecd-bdfe-4c9d-bf57-d1061f7a7e6f'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:02:20.710562 [ 4930 ] {e0b2750d-4904-469d-b257-cd1b53bdaa62} executeQuery: Code: 60. DB::Exception: Table test_5.ghdata does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38992) (comment: 03272_ghdata_object_to_json_alter_shared_data.sh) (query 1, line 1) (in query: INSERT INTO ghdata FORMAT JSONAsObject), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013cf9b5f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144148c9 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001441ace8 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001484a2e4 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014851d18 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:02:20.759420 [ 4930 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.ghdata does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013cf9b5f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144148c9 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001441ace8 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001484a2e4 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014851d18 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:02:20.786778 [ 5987 ] {8833c8a1-9977-42ce-87c8-8959e265bba6} 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]:39008) (comment: 02553_type_object_analyzer.sql) (query 2, line 2) (in query: SET allow_experimental_object_type = 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:02:20.835766 [ 5987 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:02:21.170042 [ 4871 ] {7d1649c5-2712-4b35-a8d9-c2ddfa455e88} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:1688783b-ed09-424d-8c89-6284e3841d07'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39528) (comment: 02002_row_level_filter_bug.sh) (in query: CREATE DATABASE IF NOT EXISTS test_livqfl2q ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:02:21.200252 [ 4871 ] {7d1649c5-2712-4b35-a8d9-c2ddfa455e88} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:1688783b-ed09-424d-8c89-6284e3841d07'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:02:21.264338 [ 4870 ] {96981d66-0b36-4187-b37a-7d312de0c44b} executeQuery: Code: 6. DB::Exception: Cannot parse string 'q' as UInt8: syntax error at begin of string. Note: there are toUInt8OrZero and toUInt8OrNull functions, which returns zero/NULL instead of throwing exception.: While processing _CAST('q' AS bad_column_tmp_alter4559712333599945898, 'UInt8') AS bad_column: default expression and column type are incompatible. (CANNOT_PARSE_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41892) (comment: 01079_alter_default_zookeeper_long.sql) (query 20, line 48) (in query: ALTER TABLE alter_default ADD COLUMN bad_column UInt8 DEFAULT 'q';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt8, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000012ec4928 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl, DB::detail::NameToUInt8, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000012ec461e 6. /build/src/Functions/FunctionsConversion.h:2472: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e85a32 7. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012e9952e 8. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012e98d5a 9. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 10. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Functions/IFunction.cpp:513: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c80999 14. /build/src/Functions/FunctionsConversion.h:3487: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000012ceb2d6 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012cc745b 16. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fc534a 17. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 18. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 19. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 20. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f75b 21. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 22. /build/src/Interpreters/ActionsDAG.cpp:413: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x0000000013eba819 23. /build/src/Interpreters/ActionsDAG.cpp:330: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x0000000013eb9e43 24. /build/src/Interpreters/ActionsVisitor.cpp:697: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000014477251 25. /build/src/Interpreters/ActionsMatcher.h:178: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000014484aaf 26. /build/src/Interpreters/ActionsVisitor.cpp:1366: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000014479512 27. /build/src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000001446f1d5 28. /build/src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x000000001444cf68 29. /build/src/Interpreters/ExpressionAnalyzer.cpp:1867: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x000000001445c216 30. /build/src/Interpreters/ExpressionAnalyzer.cpp:1902: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x000000001445c649 31. /build/src/Storages/ColumnsDescription.cpp:1018: DB::(anonymous namespace)::validateColumnsDefaultsAndGetSampleBlockImpl(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr, bool) @ 0x0000000015c25d31 2025.07.13 02:02:21.282206 [ 4870 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string 'q' as UInt8: syntax error at begin of string. Note: there are toUInt8OrZero and toUInt8OrNull functions, which returns zero/NULL instead of throwing exception.: While processing _CAST('q' AS bad_column_tmp_alter4559712333599945898, 'UInt8') AS bad_column: default expression and column type are incompatible. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt8, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000012ec4928 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl, DB::detail::NameToUInt8, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000012ec461e 6. /build/src/Functions/FunctionsConversion.h:2472: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e85a32 7. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012e9952e 8. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012e98d5a 9. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 10. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Functions/IFunction.cpp:513: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c80999 14. /build/src/Functions/FunctionsConversion.h:3487: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000012ceb2d6 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012cc745b 16. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fc534a 17. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 18. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 19. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 20. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f75b 21. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 22. /build/src/Interpreters/ActionsDAG.cpp:413: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x0000000013eba819 23. /build/src/Interpreters/ActionsDAG.cpp:330: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x0000000013eb9e43 24. /build/src/Interpreters/ActionsVisitor.cpp:697: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000014477251 25. /build/src/Interpreters/ActionsMatcher.h:178: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000014484aaf 26. /build/src/Interpreters/ActionsVisitor.cpp:1366: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000014479512 27. /build/src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000001446f1d5 28. /build/src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x000000001444cf68 29. /build/src/Interpreters/ExpressionAnalyzer.cpp:1867: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x000000001445c216 30. /build/src/Interpreters/ExpressionAnalyzer.cpp:1902: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x000000001445c649 31. /build/src/Storages/ColumnsDescription.cpp:1018: DB::(anonymous namespace)::validateColumnsDefaultsAndGetSampleBlockImpl(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr, bool) @ 0x0000000015c25d31 2025.07.13 02:02:21.376431 [ 4922 ] {67697e1d-99a2-4a72-b6b6-3965dca6247a} executeQuery: Code: 215. DB::Exception: Column key_a is not under aggregate function and not in GROUP BY keys. In query SELECT key_a + key_b AS d, rank() OVER (PARTITION BY key_a + key_b) AS f FROM (SELECT rand() % 10 AS key_a, rand(1) % 5 AS key_b, number FROM numbers(100)) GROUP BY key_a, key_b WITH ROLLUP ORDER BY multiIf(d = 0, key_a, NULL) ASC. (NOT_AN_AGGREGATE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44164) (comment: 03146_tpc_ds_grouping.sql) (query 3, line 21) (in query: SELECT key_a + key_b AS d, rank() OVER (PARTITION BY key_a + key_b) AS f FROM ( SELECT rand() % 10 AS key_a, rand(1) % 5 AS key_b, number FROM numbers(100) ) GROUP BY key_a, key_b WITH ROLLUP ORDER BY multiIf(d = 0, key_a, NULL) ASC FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Analyzer/ValidationUtils.cpp:199: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000013f86ce9 5. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000013f86917 6. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000013f86917 7. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000013f86917 8. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000013f86917 9. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000013f86917 10. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000013f86917 11. /build/src/Analyzer/ValidationUtils.cpp:359: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000013f85f8a 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f332a5 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:02:21.429478 [ 4922 ] {} TCPHandler: Code: 215. DB::Exception: Column key_a is not under aggregate function and not in GROUP BY keys. In query SELECT key_a + key_b AS d, rank() OVER (PARTITION BY key_a + key_b) AS f FROM (SELECT rand() % 10 AS key_a, rand(1) % 5 AS key_b, number FROM numbers(100)) GROUP BY key_a, key_b WITH ROLLUP ORDER BY multiIf(d = 0, key_a, NULL) ASC. (NOT_AN_AGGREGATE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Analyzer/ValidationUtils.cpp:199: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000013f86ce9 5. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000013f86917 6. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000013f86917 7. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000013f86917 8. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000013f86917 9. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000013f86917 10. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000013f86917 11. /build/src/Analyzer/ValidationUtils.cpp:359: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000013f85f8a 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f332a5 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:02:21.602164 [ 4930 ] {1e886550-1ba8-42a2-aac8-b398ea7cf45b} executeQuery: Code: 60. DB::Exception: Table test_5.ghdata does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39030) (comment: 03272_ghdata_object_to_json_alter_shared_data.sh) (query 1, line 1) (in query: ALTER TABLE ghdata MODIFY column data JSON(max_dynamic_paths=8) SETTINGS mutations_sync=1), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013cf9b5f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144148c9 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001441ace8 7. /build/src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x0000000013cd7e42 8. /build/src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013cd7a7f 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fbcf4 10. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:02:21.638944 [ 4930 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.ghdata does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013cf9b5f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144148c9 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001441ace8 7. /build/src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x0000000013cd7e42 8. /build/src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013cd7a7f 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fbcf4 10. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:02:21.883790 [ 6538 ] {1ace41f1-46c1-417e-8cc7-c43727c356ab} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:d1f3e90a-6da9-436a-a621-8cbf15ac503e'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39548) (comment: 00054_join_string.sql) (in query: CREATE DATABASE IF NOT EXISTS test_3ki1dtsx ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:02:21.902789 [ 6538 ] {1ace41f1-46c1-417e-8cc7-c43727c356ab} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:d1f3e90a-6da9-436a-a621-8cbf15ac503e'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:02:22.076720 [ 6532 ] {d70597df-85bd-4da6-bb99-33d69cd86588} 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]:39048) (comment: 02725_object_column_alter.sql) (query 1, line 1) (in query: -- Eventually this ALTER should be fixed SET allow_experimental_object_type=1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:02:22.109697 [ 6532 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:02:22.197108 [ 4922 ] {b21baedc-cf8c-4fea-b8a6-30807303ba46} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:ba8af122-4ddf-47d6-ab9d-cf4c2c8b993e'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39560) (comment: 00818_inner_join_bug_3567.sql) (in query: CREATE DATABASE IF NOT EXISTS test_c4u2o8g9 ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:02:22.216883 [ 4922 ] {b21baedc-cf8c-4fea-b8a6-30807303ba46} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:ba8af122-4ddf-47d6-ab9d-cf4c2c8b993e'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:02:22.318745 [ 3543 ] {17b040fc-ddb9-47f7-8fa4-3c6d862fb077} 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]:39070) (comment: 03272_ghdata_object_to_json_alter_shared_data.sh) (query 1, line 1) (in query: SELECT count() FROM ghdata WHERE NOT ignore(*)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f633d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:02:22.397986 [ 3543 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'ghdata' in scope SELECT count() FROM ghdata WHERE NOT ignore(*). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f633d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:02:22.618515 [ 5117 ] {1f15001a-8c7b-4d44-ad51-dc58b8065b51} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:d1aa2ab2-7c81-4536-8105-1c9983e74e84'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39570) (comment: 03202_dynamic_null_map_subcolumn.gen.sql) (in query: CREATE DATABASE IF NOT EXISTS test_u0m3t8x9 ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:02:22.693050 [ 5117 ] {1f15001a-8c7b-4d44-ad51-dc58b8065b51} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:d1aa2ab2-7c81-4536-8105-1c9983e74e84'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:02:23.088365 [ 3543 ] {69f48f74-955c-4f93-aff9-fbd1122eed36} 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]:39108) (comment: 03272_ghdata_object_to_json_alter_shared_data.sh) (query 1, line 1) (in query: SELECT data.repo.name, count() AS stars FROM ghdata WHERE data.type = 'WatchEvent' GROUP BY data.repo.name ORDER BY stars DESC, data.repo.name LIMIT 5), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f633d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:02:23.183756 [ 6162 ] {591f2f28-2e0d-44b6-834a-0ee9ea8bb272} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:74380048-1f58-4e39-9bab-f393ca766ebd'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39578) (comment: 01105_string_like.sql) (in query: CREATE DATABASE IF NOT EXISTS test_tneylht2 ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:02:23.188071 [ 3543 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'ghdata' in scope SELECT data.repo.name, count() AS stars FROM ghdata WHERE data.type = 'WatchEvent' GROUP BY data.repo.name ORDER BY stars DESC, data.repo.name ASC LIMIT 5. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f633d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:02:23.196936 [ 6162 ] {591f2f28-2e0d-44b6-834a-0ee9ea8bb272} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:74380048-1f58-4e39-9bab-f393ca766ebd'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:02:23.626650 [ 4870 ] {f5e185d3-27c2-42bf-83ea-4598adbc008d} executeQuery: Code: 41. DB::Exception: Cannot parse DateTime: Cannot parse DateTime from String: While processing _CAST('0' AS other_date_tmp_alter11260394023814205504, 'DateTime') AS other_date: default expression and column type are incompatible. (CANNOT_PARSE_DATETIME) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:41892) (comment: 01079_alter_default_zookeeper_long.sql) (query 24, line 56) (in query: ALTER TABLE alter_default MODIFY COLUMN other_date DateTime;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/IO/ReadHelpers.cpp:1597: void DB::readDateTimeTextFallback(long&, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x000000000fb8e481 5. /build/src/IO/ReadHelpers.h:1216: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000012f8e035 6. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000012f8dd3e 7. /build/src/Functions/FunctionsConversion.h:2472: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e93430 8. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eae0a3 9. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ead81a 10. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 11. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 14. /build/src/Functions/IFunction.cpp:513: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c80999 15. /build/src/Functions/FunctionsConversion.h:3487: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000012ceb2d6 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012cc745b 17. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fc534a 18. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 19. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 20. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 21. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f75b 22. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 23. /build/src/Interpreters/ActionsDAG.cpp:413: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x0000000013eba819 24. /build/src/Interpreters/ActionsDAG.cpp:330: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x0000000013eb9e43 25. /build/src/Interpreters/ActionsVisitor.cpp:697: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000014477251 26. /build/src/Interpreters/ActionsMatcher.h:178: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000014484aaf 27. /build/src/Interpreters/ActionsVisitor.cpp:1366: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000014479512 28. /build/src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000001446f1d5 29. /build/src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x000000001444cf68 30. /build/src/Interpreters/ExpressionAnalyzer.cpp:1867: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x000000001445c216 31. /build/src/Interpreters/ExpressionAnalyzer.cpp:1902: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x000000001445c649 2025.07.13 02:02:23.643090 [ 4870 ] {} TCPHandler: Code: 41. DB::Exception: Cannot parse DateTime: Cannot parse DateTime from String: While processing _CAST('0' AS other_date_tmp_alter11260394023814205504, 'DateTime') AS other_date: default expression and column type are incompatible. (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/IO/ReadHelpers.cpp:1597: void DB::readDateTimeTextFallback(long&, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x000000000fb8e481 5. /build/src/IO/ReadHelpers.h:1216: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000012f8e035 6. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000012f8dd3e 7. /build/src/Functions/FunctionsConversion.h:2472: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e93430 8. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eae0a3 9. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ead81a 10. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 11. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 14. /build/src/Functions/IFunction.cpp:513: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c80999 15. /build/src/Functions/FunctionsConversion.h:3487: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000012ceb2d6 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012cc745b 17. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fc534a 18. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 19. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 20. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 21. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f75b 22. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 23. /build/src/Interpreters/ActionsDAG.cpp:413: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x0000000013eba819 24. /build/src/Interpreters/ActionsDAG.cpp:330: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x0000000013eb9e43 25. /build/src/Interpreters/ActionsVisitor.cpp:697: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000014477251 26. /build/src/Interpreters/ActionsMatcher.h:178: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000014484aaf 27. /build/src/Interpreters/ActionsVisitor.cpp:1366: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000014479512 28. /build/src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000001446f1d5 29. /build/src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x000000001444cf68 30. /build/src/Interpreters/ExpressionAnalyzer.cpp:1867: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x000000001445c216 31. /build/src/Interpreters/ExpressionAnalyzer.cpp:1902: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x000000001445c649 2025.07.13 02:02:23.783407 [ 6619 ] {017e6b28-55d6-4c5c-8eb9-0798006f7fbf} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:3ee994aa-e937-412f-bd0c-f8022f42eded'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39588) (comment: 02374_in_tuple_index.sql) (in query: CREATE DATABASE IF NOT EXISTS test_uuhtc9yz ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:02:23.787484 [ 6619 ] {017e6b28-55d6-4c5c-8eb9-0798006f7fbf} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:3ee994aa-e937-412f-bd0c-f8022f42eded'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:02:23.826077 [ 5128 ] {43d834f9-bc90-47f1-89ec-c55b264dd025} 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]:39112) (comment: 03272_ghdata_object_to_json_alter_shared_data.sh) (query 1, line 1) (in query: SELECT data.payload.commits[].author.name AS name, count() AS c FROM ghdata ARRAY JOIN data.payload.commits[].author.name GROUP BY name ORDER BY c DESC, name LIMIT 5), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f633d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:02:23.866119 [ 5128 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'ghdata' in scope SELECT data.payload.commits.:`Array(JSON)`.author.name AS name, count() AS c FROM ghdata ARRAY JOIN data.payload.commits.:`Array(JSON)`.author.name GROUP BY name ORDER BY c DESC, name ASC LIMIT 5. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f633d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:02:24.306870 [ 6637 ] {da1d5268-dbe8-47d2-9de8-18cb07efa441} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:ccbc653d-d9ce-4ec0-84e2-051399e4c359'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39606) (comment: 02519_monotonicity_fuzz.sql) (in query: CREATE DATABASE IF NOT EXISTS test_gxfziybw ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:02:24.310744 [ 6637 ] {da1d5268-dbe8-47d2-9de8-18cb07efa441} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:ccbc653d-d9ce-4ec0-84e2-051399e4c359'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:02:24.438770 [ 5998 ] {60b95cf9-7a7e-4867-ab84-26db7a2a474b} 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]:39128) (comment: 03272_ghdata_object_to_json_alter_shared_data.sh) (query 1, line 1) (in query: SELECT max(data.payload.pull_request.assignees[].size0) FROM ghdata), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f633d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:02:24.493022 [ 5998 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'ghdata' in scope SELECT max(data.payload.pull_request.assignees.:`Array(JSON)`.size0) FROM ghdata. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f633d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:02:24.709701 [ 6611 ] {aae7d773-b810-41de-82f7-0363b04bb950} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:cf8cf0dd-5632-4e56-ab74-69d76dce07a3'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39628) (comment: 00537_quarters.sql) (in query: CREATE DATABASE IF NOT EXISTS test_0wa1fcar ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:02:24.712967 [ 6611 ] {aae7d773-b810-41de-82f7-0363b04bb950} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:cf8cf0dd-5632-4e56-ab74-69d76dce07a3'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:02:25.079707 [ 5998 ] {b98c79b9-1bae-4f43-8b06-fa6759b64ea3} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:cc031fa8-fc6d-4592-a8a2-0820d2c5ab39'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39642) (comment: 01267_alter_default_key_columns_zookeeper_long.sql) (in query: CREATE DATABASE IF NOT EXISTS test_uirpaokr ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:02:25.091865 [ 5998 ] {b98c79b9-1bae-4f43-8b06-fa6759b64ea3} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:cc031fa8-fc6d-4592-a8a2-0820d2c5ab39'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:02:25.393866 [ 3543 ] {eea3c293-19cc-4194-bb28-3294c1c3ec2f} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:ad62c58a-0584-4789-80ca-57f21f8f74b9'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39662) (comment: 00732_base64_functions.sql) (in query: CREATE DATABASE IF NOT EXISTS test_zm0soxxm ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:02:25.401311 [ 3543 ] {eea3c293-19cc-4194-bb28-3294c1c3ec2f} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:ad62c58a-0584-4789-80ca-57f21f8f74b9'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:02:25.743718 [ 4879 ] {a64c3e1e-a792-4f2c-b41c-f8ad2e0235c6} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:86150eb9-83a6-4e8c-8248-df55949e2498'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39672) (comment: 01197_summing_enum.sql) (in query: CREATE DATABASE IF NOT EXISTS test_fujw2fll ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:02:25.769963 [ 4879 ] {a64c3e1e-a792-4f2c-b41c-f8ad2e0235c6} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:86150eb9-83a6-4e8c-8248-df55949e2498'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:02:26.070583 [ 3543 ] {507b19d5-e03a-4796-868f-a9c6d5a5302e} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:44ebf92f-2816-4895-9923-bcd4085f392b'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39686) (comment: 01021_only_tuple_columns.sql) (in query: CREATE DATABASE IF NOT EXISTS test_77tyzpfg ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:02:26.133722 [ 3543 ] {507b19d5-e03a-4796-868f-a9c6d5a5302e} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:44ebf92f-2816-4895-9923-bcd4085f392b'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:02:26.557542 [ 5128 ] {d60134e1-3aed-426e-8444-6737866d327a} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:a850b076-2508-49c6-8bab-bc4576384a93'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39694) (comment: 01543_avro_deserialization_with_lc.sh) (in query: CREATE DATABASE IF NOT EXISTS test_c4ny5fzq ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:02:26.563105 [ 5128 ] {d60134e1-3aed-426e-8444-6737866d327a} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:a850b076-2508-49c6-8bab-bc4576384a93'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:02:26.580167 [ 5128 ] {} HTTPServerRequest: Got an HTTP request with no content length and no chunked/multipart encoding, it may be impossible to distinguish graceful EOF from abnormal connection loss 2025.07.13 02:02:26.785869 [ 6532 ] {2b47b054-8278-415e-82b0-bc952c7bd075} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:422b8ac2-5e4d-4e3f-a385-ec350835d8e5'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39710) (comment: 02494_query_cache_drop_cache.sql) (in query: CREATE DATABASE IF NOT EXISTS test_uxcgr276 ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:02:26.888749 [ 6532 ] {2b47b054-8278-415e-82b0-bc952c7bd075} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:422b8ac2-5e4d-4e3f-a385-ec350835d8e5'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:02:27.263006 [ 6538 ] {76b24aec-a6f5-485e-afff-d370ede2f192} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:45b2fd3d-5f3c-4967-a5bd-0d6544dcb86c'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39722) (comment: 01765_hashed_dictionary_simple_key.sql) (in query: CREATE DATABASE IF NOT EXISTS test_1cdq7in2 ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:02:27.267872 [ 6538 ] {76b24aec-a6f5-485e-afff-d370ede2f192} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:45b2fd3d-5f3c-4967-a5bd-0d6544dcb86c'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:02:27.659042 [ 5987 ] {c365b3eb-4c5c-4bb1-aac5-d613d754c53b} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:e48296df-44e5-464c-9b08-ff29e4feb456'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39730) (comment: 03168_loop_engine_with_parallel_replicas.sql) (in query: CREATE DATABASE IF NOT EXISTS test_hkey001m ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:02:27.665435 [ 5987 ] {c365b3eb-4c5c-4bb1-aac5-d613d754c53b} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:e48296df-44e5-464c-9b08-ff29e4feb456'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:02:28.145990 [ 6619 ] {666770e8-3eaf-4710-932d-5d8a5dcfd48a} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:2208f2b8-03ce-4898-a249-0db1f64ac2cc'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39746) (comment: 02775_show_columns_called_from_clickhouse.sql) (in query: CREATE DATABASE IF NOT EXISTS test_nyj5kagw ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:02:28.151472 [ 6619 ] {666770e8-3eaf-4710-932d-5d8a5dcfd48a} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:2208f2b8-03ce-4898-a249-0db1f64ac2cc'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:02:28.493619 [ 3543 ] {7485201f-06ca-4a71-8a75-4fd113c0ddf3} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:4686157a-62c1-4e0d-9b9a-aab9252b79a3'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39768) (comment: 02976_system_zookeeper_filters.sql) (in query: CREATE DATABASE IF NOT EXISTS test_9yxsqxxb ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:02:28.520154 [ 3543 ] {7485201f-06ca-4a71-8a75-4fd113c0ddf3} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:4686157a-62c1-4e0d-9b9a-aab9252b79a3'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:02:28.810997 [ 4922 ] {d4e66428-e293-4098-b777-9cc2693ab467} 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]:39104) (comment: 02812_pointwise_array_operations.sql) (query 14, line 14) (in query: SELECT ([12,13] % [5,6]);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000d3a8982 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:02:28.839624 [ 4922 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Array(UInt8) and Array(UInt8) of arguments of function modulo: In scope SELECT [12, 13] % [5, 6]. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000d3a8982 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:02:29.023842 [ 6637 ] {91efec3a-c2e2-4bab-af54-96ec44b7f8cd} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:c4a09405-797a-4d7a-804d-544e88b3e511'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39784) (comment: 01155_rename_move_materialized_view.sql) (in query: CREATE DATABASE IF NOT EXISTS test_3781bewc ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:02:29.027112 [ 6637 ] {91efec3a-c2e2-4bab-af54-96ec44b7f8cd} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:c4a09405-797a-4d7a-804d-544e88b3e511'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:02:29.185288 [ 4922 ] {6a7455ad-7a1f-4e24-bdf5-5876df5c6b41} 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]:39104) (comment: 02812_pointwise_array_operations.sql) (query 15, line 15) (in query: SELECT ([2,3,4]-[1,-2,10,29]);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/FunctionBinaryArithmetic.h:1368: DB::FunctionBinaryArithmetic::executeArraysImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000cf93262 5. /build/src/Functions/FunctionBinaryArithmetic.h:2515: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000cf8f6a7 6. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000cf8d11f 7. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000cf8bd34 8. /build/src/Functions/FunctionBinaryArithmetic.h:1353: DB::FunctionBinaryArithmetic::executeArraysImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000cf9279d 9. /build/src/Functions/FunctionBinaryArithmetic.h:2515: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000cf8f6a7 10. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000cf8d11f 11. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000cf8bd34 12. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 13. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 14. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 31. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 2025.07.13 02:02:29.226951 [ 4922 ] {} TCPHandler: Code: 190. DB::Exception: Two arguments for function minus must have equal sizes: In scope SELECT [2, 3, 4] - [1, -2, 10, 29]. (SIZES_OF_ARRAYS_DONT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/FunctionBinaryArithmetic.h:1368: DB::FunctionBinaryArithmetic::executeArraysImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000cf93262 5. /build/src/Functions/FunctionBinaryArithmetic.h:2515: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000cf8f6a7 6. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000cf8d11f 7. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000cf8bd34 8. /build/src/Functions/FunctionBinaryArithmetic.h:1353: DB::FunctionBinaryArithmetic::executeArraysImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000cf9279d 9. /build/src/Functions/FunctionBinaryArithmetic.h:2515: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000cf8f6a7 10. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000cf8d11f 11. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000cf8bd34 12. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 13. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 14. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 31. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 2025.07.13 02:02:29.462049 [ 6619 ] {fac88aa3-5030-4b43-b193-13717de40f11} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:885162fa-aa0a-4303-acfa-fe31ef40a3e8'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42550) (comment: 00047_bar.sql) (in query: CREATE DATABASE IF NOT EXISTS test_55hytmo2 ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:02:29.466174 [ 6619 ] {fac88aa3-5030-4b43-b193-13717de40f11} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:885162fa-aa0a-4303-acfa-fe31ef40a3e8'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:02:29.597005 [ 6612 ] {08697a45-afbf-4aa4-8ac3-39d15e2ea386} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_m2kyy9ix.wikistat1 (a89a7882-5290-4dce-9d96-642db4245bc0)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59904) (comment: 02494_zero_copy_projection_cancel_fetch.sh) (query 1, line 1) (in query: INSERT INTO wikistat1 SELECT toDateTime('2020-10-01 00:00:00'), 'hello', 'world', '/data/path', 10 from numbers(1000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000148054a6 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:830: DB::InterpreterInsertQuery::execute() @ 0x0000000014851d39 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:02:29.644298 [ 6612 ] {} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_m2kyy9ix.wikistat1 (a89a7882-5290-4dce-9d96-642db4245bc0)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000148054a6 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:830: DB::InterpreterInsertQuery::execute() @ 0x0000000014851d39 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:02:29.904754 [ 4912 ] {ad5a8819-6c5d-47e2-afb0-8d72d9b42dda} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:4d43cd21-94e7-4c93-ad53-e0ea5e38313d'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42566) (comment: 03305_mutations_counters_replicated.sh) (in query: CREATE DATABASE IF NOT EXISTS test_revqyt6n ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:02:29.916553 [ 4912 ] {ad5a8819-6c5d-47e2-afb0-8d72d9b42dda} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:4d43cd21-94e7-4c93-ad53-e0ea5e38313d'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:02:30.160975 [ 6637 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:59908, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fc62e75 3. /build/src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000fc623ee 4. /build/src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000fc62923 5. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 6. /build/src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000001680643e 7. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 12. ? @ 0x00007f7210eb6ac3 13. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:02:30.169138 [ 6637 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:59908, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fc62e75 3. /build/src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000fc623ee 4. /build/src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000fc62923 5. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 6. /build/src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000001680643e 7. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 12. ? @ 0x00007f7210eb6ac3 13. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:02:30.190710 [ 6612 ] {044cc034-4739-4607-a30b-fc99abea8864} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:6a27e131-bb84-44ba-a7cb-f9a489fea2da'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 02884_async_insert_native_protocol_1.sh) (in query: CREATE DATABASE IF NOT EXISTS test_t8fjynxn ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:02:30.211889 [ 6612 ] {044cc034-4739-4607-a30b-fc99abea8864} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:6a27e131-bb84-44ba-a7cb-f9a489fea2da'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:02:30.426296 [ 4922 ] {25a8cef6-6c52-4220-821e-5c4a36082171} 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]:39104) (comment: 02812_pointwise_array_operations.sql) (query 18, line 18) (in query: SELECT x, y, x+y FROM a;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/FunctionBinaryArithmetic.h:1368: DB::FunctionBinaryArithmetic::executeArraysImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000de8b202 5. /build/src/Functions/FunctionBinaryArithmetic.h:2515: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000de87a87 6. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000de856b8 7. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 8. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 11. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:02:30.485229 [ 4922 ] {} TCPHandler: Code: 190. DB::Exception: Two arguments for function plus must have equal sizes: while executing 'FUNCTION plus(__table1.x :: 2, __table1.y : 0) -> plus(__table1.x, __table1.y) Array(UInt64) : 3'. (SIZES_OF_ARRAYS_DONT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/FunctionBinaryArithmetic.h:1368: DB::FunctionBinaryArithmetic::executeArraysImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000de8b202 5. /build/src/Functions/FunctionBinaryArithmetic.h:2515: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000de87a87 6. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000de856b8 7. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 8. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 11. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:02:30.649521 [ 6619 ] {d51591b8-6b41-4b20-8f19-261fbc0c9fa8} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:f55e523b-2e5c-4b5e-bb9d-8b6413ee4617'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42576) (comment: 02832_alter_max_sessions_for_user.sh) (in query: CREATE DATABASE IF NOT EXISTS test_xdn80ppf ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:02:30.656728 [ 6619 ] {d51591b8-6b41-4b20-8f19-261fbc0c9fa8} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:f55e523b-2e5c-4b5e-bb9d-8b6413ee4617'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:02:30.962938 [ 6612 ] {0ea27263-d0e2-47e6-878c-96f34de31fbb} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:2d201d3f-1b7f-47e2-9037-16417c687626'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42594) (comment: 00016_any_if_distributed_cond_always_false.sql) (in query: CREATE DATABASE IF NOT EXISTS test_reczqsjd ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:02:30.981808 [ 6612 ] {0ea27263-d0e2-47e6-878c-96f34de31fbb} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:2d201d3f-1b7f-47e2-9037-16417c687626'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:02:31.346601 [ 4870 ] {5d241a39-e0ac-45f0-861f-f97d801eede6} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:532919fc-8834-48ec-ac52-e0ede8b42d68'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42614) (comment: 03147_parquet_memory_tracking.sql) (in query: CREATE DATABASE IF NOT EXISTS test_ip4o8k9s ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:02:31.385122 [ 4870 ] {5d241a39-e0ac-45f0-861f-f97d801eede6} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:532919fc-8834-48ec-ac52-e0ede8b42d68'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:02:31.707360 [ 5998 ] {08ec735e-14cf-49ea-9e69-3825526021bc} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:ac725a15-bc91-4895-bbdb-c997a9f286bc'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42618) (comment: 01098_temporary_and_external_tables.sh) (in query: CREATE DATABASE IF NOT EXISTS test_e3wzcn3x ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:02:31.712458 [ 5998 ] {08ec735e-14cf-49ea-9e69-3825526021bc} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:ac725a15-bc91-4895-bbdb-c997a9f286bc'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:02:32.181742 [ 6612 ] {e7c83d38-b3c4-48ee-a0f1-87d05f87b857} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:32da1e8b-53e9-4d47-acde-a06f5f4bca65'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42628) (comment: 01527_clickhouse_local_optimize.sh) (in query: CREATE DATABASE IF NOT EXISTS test_e32rcraf ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:02:32.197652 [ 6612 ] {e7c83d38-b3c4-48ee-a0f1-87d05f87b857} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:32da1e8b-53e9-4d47-acde-a06f5f4bca65'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:02:32.491625 [ 6611 ] {5a5e0454-bb71-4618-8899-0ef56dca0440} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:89addc4b-1b63-4f86-bf85-ac8b2afeab27'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42642) (comment: 01646_system_restart_replicas_smoke.sql) (in query: CREATE DATABASE IF NOT EXISTS test_mz455pbn ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:02:32.498582 [ 6611 ] {5a5e0454-bb71-4618-8899-0ef56dca0440} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:89addc4b-1b63-4f86-bf85-ac8b2afeab27'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:02:32.709863 [ 4274 ] {b231133a-8802-4962-be89-6b688b8a418c::all_1_1_0_6} MutatePlainMergeTreeTask: 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)) 2025.07.13 02:02:32.874518 [ 3543 ] {3695d634-a100-411a-98fc-c382cbcbfc16} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:2d2e005b-3e2a-42ce-84aa-dfcbfb383250'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42656) (comment: 02337_drop_filesystem_cache_access.sh) (in query: CREATE DATABASE IF NOT EXISTS test_rgzw8qds ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:02:32.890013 [ 3543 ] {3695d634-a100-411a-98fc-c382cbcbfc16} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:2d2e005b-3e2a-42ce-84aa-dfcbfb383250'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:02:32.914191 [ 6614 ] {57e7cd62-b9ab-4754-a7fc-ae28df884665} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_6.txt' with part 'all_1_1_0_5' reason: '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))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Storages/MergeTree/MergeTreeMutationStatus.cpp:33: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x000000001639ba0e 2. /build/src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000001655dce8 3. /build/src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000001655ed84 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd3ec 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 . (UNFINISHED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39258) (comment: 01900_kill_mutation_parallel_long.sh) (query 5, line 5) (in query: alter table data_01900_2 update s = 'bar_5' where 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&, String&&) @ 0x000000001639bb59 4. /build/src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x000000001639ba6d 5. /build/src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000001655dce8 6. /build/src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000001655ed84 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd3ec 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:02:32.945357 [ 4274 ] {b231133a-8802-4962-be89-6b688b8a418c::all_1_1_0_6} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 9. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000001494103a 7. /build/src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000016450695 8. /build/src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x000000001644fcf1 9. /build/src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x0000000016594cb8 10. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 11. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 13. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:02:32.948770 [ 4274 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b231133a-8802-4962-be89-6b688b8a418c::all_1_1_0_6}: 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 9. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000001494103a 7. /build/src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000016450695 8. /build/src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x000000001644fcf1 9. /build/src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x0000000016594cb8 10. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 11. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 13. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:02:32.966738 [ 6614 ] {} TCPHandler: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_6.txt' with part 'all_1_1_0_5' reason: '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))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Storages/MergeTree/MergeTreeMutationStatus.cpp:33: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x000000001639ba0e 2. /build/src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000001655dce8 3. /build/src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000001655ed84 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd3ec 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 . (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&, String&&) @ 0x000000001639bb59 4. /build/src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x000000001639ba6d 5. /build/src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000001655dce8 6. /build/src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000001655ed84 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd3ec 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:02:33.293756 [ 4870 ] {6cdf6ad4-ec09-4043-b005-502f2acfe88c} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:c728cd80-2693-49fc-bf40-40fa67850df7'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42664) (comment: 03312_check_table_grant.sh) (in query: CREATE DATABASE IF NOT EXISTS test_nv9krm2l ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:02:33.367444 [ 4870 ] {6cdf6ad4-ec09-4043-b005-502f2acfe88c} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:c728cd80-2693-49fc-bf40-40fa67850df7'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:02:33.644517 [ 5117 ] {fecedef6-3d1d-4ff5-8322-215613f12380} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:fa55117d-d92a-4207-978f-f3fc73f5b690'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42672) (comment: 02102_sql_user_defined_functions_create_if_not_exists.sql) (in query: CREATE DATABASE IF NOT EXISTS test_1rafv9qs ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:02:33.660950 [ 5117 ] {fecedef6-3d1d-4ff5-8322-215613f12380} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:fa55117d-d92a-4207-978f-f3fc73f5b690'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:02:34.069276 [ 4870 ] {dad2d462-8b02-4cbf-87a8-ce35eaab1932} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:cf0ba099-6f75-4e66-9bf8-58f74d551565'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42682) (comment: 01035_concurrent_move_partition_from_table_zookeeper.sh) (in query: CREATE DATABASE IF NOT EXISTS test_oxkeue3n ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:02:34.075514 [ 4870 ] {dad2d462-8b02-4cbf-87a8-ce35eaab1932} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '933e750fc1f6:9000:40c183f5-09a2-43aa-9bf7-ce5db0b04069', current host ID: '933e750fc1f6:9000:cf0ba099-6f75-4e66-9bf8-58f74d551565'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:02:34.739681 [ 6168 ] {6937d919-ea93-42c7-98a1-49718a217272} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_m2kyy9ix.wikistat2 (abcdc9c8-22fd-4f0a-ad6c-1958420efc55)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60134) (comment: 02494_zero_copy_projection_cancel_fetch.sh) (query 1, line 1) (in query: ALTER TABLE wikistat2 MODIFY SETTING max_replicated_fetches_network_bandwidth = 0), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000148054a6 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:136: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fbfdf 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:02:34.782499 [ 6168 ] {} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_m2kyy9ix.wikistat2 (abcdc9c8-22fd-4f0a-ad6c-1958420efc55)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000148054a6 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:136: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fbfdf 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:02:36.180148 [ 6532 ] {872cd20f-5da3-4eff-83b7-f1cf2167d335} DNSResolver: Cannot resolve host (localhos), error 0: Host not found. 2025.07.13 02:02:36.307439 [ 5128 ] {0deea90c-61cf-4854-9594-4af08c597468} 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]:60182) (comment: 03279_pr_3_way_joins_full_first.gen.sql) (query 5, line 6) (in query: CREATE TABLE test_table_join_1 (`id` UInt8, `value` String) ENGINE = ReplicatedMergeTree('/clickhouse/{database}/test_table_join_1', 'r1') ORDER BY id SETTINGS index_granularity = 1, min_bytes_for_wide_part = 811399148, 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 = 506126185, compact_parts_max_granules_to_buffer = 25, compact_parts_merge_max_bytes_to_prefetch_part = 4278275, merge_max_block_size = 12593, old_parts_lifetime = 177., 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 = 1367242937, index_granularity_bytes = 30383796, 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 = true, marks_compress_block_size = 56791, primary_key_compress_block_size = 40970, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000013cc1696 5. /build/src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013cc32f5 6. /build/src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc384b 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:02:36.364910 [ 6532 ] {872cd20f-5da3-4eff-83b7-f1cf2167d335} Cluster: Code: 198. DB::NetException: Not found address of host: localhos. (DNS_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000fa99429 3. /build/src/Common/DNSResolver.cpp:113: DB::(anonymous namespace)::hostByName(String const&) @ 0x000000000fa9670f 4. /build/src/Common/DNSResolver.cpp:138: DB::DNSResolver::getResolvedIPAdressessWithFiltering(String const&) @ 0x000000000fa95228 5. /build/src/Common/DNSResolver.cpp:256: DB::DNSResolver::resolveIPAddressWithCache(String const&) @ 0x000000000fa9554c 6. /build/src/Common/DNSResolver.cpp:305: DB::DNSResolver::resolveAddress(String const&, unsigned short) @ 0x000000000fa96233 7. /build/src/Interpreters/Cluster.cpp:82: DB::Cluster::Address::getResolvedAddress() const @ 0x000000001431b9e5 8. /build/src/Interpreters/Cluster.cpp:95: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x000000001431cb0d 9. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Cluster::Address* std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x000000001432a240 10. /build/contrib/llvm-project/libcxx/include/vector:1558: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x0000000014324471 11. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000011701407 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3bbcc 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:02:36.409957 [ 5128 ] {} TCPHandler: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000013cc1696 5. /build/src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013cc32f5 6. /build/src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc384b 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:02:36.938673 [ 4270 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a87df19b-d0e7-4931-8397-c37ae657bdc8::all_7_12_1}: Code: 241. DB::Exception: Thread memory tracker: fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000000fb2dc4b 4. /build/src/Common/MemoryTracker.cpp:196: MemoryTracker::injectFault() const @ 0x000000000fb2b6cd 5. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:153: DB::MergePlainMergeTreeTask::finish() @ 0x0000000016593639 6. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:72: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000016592af2 7. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 8. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:02:38.229849 [ 4870 ] {d0aabaff-24b6-4cb2-b135-5a8c1d1e781e} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_m2kyy9ix.wikistat1 (a89a7882-5290-4dce-9d96-642db4245bc0)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60248) (comment: 02494_zero_copy_projection_cancel_fetch.sh) (query 1, line 2) (in query: DROP TABLE IF EXISTS wikistat1 SYNC;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000148054a6 5. /build/src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001483251c 6. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 7. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:02:38.312668 [ 4870 ] {} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_m2kyy9ix.wikistat1 (a89a7882-5290-4dce-9d96-642db4245bc0)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000148054a6 5. /build/src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001483251c 6. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 7. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:02:38.810122 [ 6615 ] {47c20782-50c3-437f-aad0-c6dcff17a35b} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_m2kyy9ix.wikistat1 (a89a7882-5290-4dce-9d96-642db4245bc0)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42710) (comment: 02494_zero_copy_projection_cancel_fetch.sh) (in query: DROP DATABASE IF EXISTS test_m2kyy9ix SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000148054a6 5. /build/src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001483251c 6. /build/src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835a47 7. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 8. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 9. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 12. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 13. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 14. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:02:38.833965 [ 6615 ] {47c20782-50c3-437f-aad0-c6dcff17a35b} DynamicQueryHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_m2kyy9ix.wikistat1 (a89a7882-5290-4dce-9d96-642db4245bc0)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000148054a6 5. /build/src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001483251c 6. /build/src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835a47 7. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 8. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 9. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 12. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 13. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 14. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:02:40.811073 [ 4870 ] {6f148d1a-c4f3-40d5-a317-240abe171464} executeQuery: Code: 167. DB::Exception: AST is too deep. Maximum: 1000. (TOO_DEEP_AST) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:35528) (comment: 01196_max_parser_depth.sh) (in query: select coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, 1))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000b152a4b 4. /build/src/Parsers/IAST.cpp:162: DB::IAST::checkDepthImpl(unsigned long) const @ 0x00000000179586cf 5. /build/src/Parsers/IAST.h:99: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8aac 6. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 7. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 8. /build/src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba32be 9. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 10. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 11. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 12. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:02:40.842837 [ 4870 ] {6f148d1a-c4f3-40d5-a317-240abe171464} DynamicQueryHandler: Code: 167. DB::Exception: AST is too deep. Maximum: 1000. (TOO_DEEP_AST), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000b152a4b 4. /build/src/Parsers/IAST.cpp:162: DB::IAST::checkDepthImpl(unsigned long) const @ 0x00000000179586cf 5. /build/src/Parsers/IAST.h:99: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8aac 6. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 7. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 8. /build/src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba32be 9. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 10. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 11. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 12. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:02:41.559834 [ 6168 ] {00f7db1b-6f50-4fba-819f-883398342326} executeQuery: Code: 42. DB::Exception: Storage ODBC requires exactly 3 parameters: ODBC('DSN', database or schema, table). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43406) (comment: 01033_storage_odbc_parsing_exception_check.sql) (query 2, line 5) (in query: CREATE TABLE BannerDict (`BannerID` UInt64, `CompaignID` UInt64) ENGINE = ODBC('DSN=pgconn;Database=postgres', bannerdict);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000009fb598b 4. /build/src/Storages/StorageXDBC.cpp:188: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:se190107](DB::StorageFactory&, String const&)::'lambda'(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000015f5a521 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ca1a22 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001481ee32 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:02:41.621432 [ 6168 ] {} TCPHandler: Code: 42. DB::Exception: Storage ODBC requires exactly 3 parameters: ODBC('DSN', database or schema, table). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000009fb598b 4. /build/src/Storages/StorageXDBC.cpp:188: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:se190107](DB::StorageFactory&, String const&)::'lambda'(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000015f5a521 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ca1a22 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001481ee32 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:02:44.503534 [ 6615 ] {f62d4537-eec3-4ced-acef-f871eb1f17d2} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=4): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43438) (comment: 02889_parts_columns_filenames.sql) (query 4, line 13) (in query: SELECT * FROM t_parts_columns_filenames ORDER BY id;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x00000000163993d1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016396620 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001639641f 10. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000163ced63 11. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000163cffce 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013b9f869 13. /build/src/DataTypes/Serializations/SerializationSparse.cpp:182: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000013c34d19 14. /build/src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000013b9fb5d 15. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000163ccfc4 16. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:59: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000163ccdcc 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x00000000162f3280 18. /build/src/Storages/MergeTree/MergeTreeDataPartWide.cpp:52: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x00000000162ee6be 19. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x00000000163d9d66 20. /build/src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x0000000016d7885f 21. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x0000000016d9cdca 22. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5520 23. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 24. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 25. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 26. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 27. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 28. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 29. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 30. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 31. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 2025.07.13 02:02:44.596293 [ 6615 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=4): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x00000000163993d1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016396620 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001639641f 10. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000163ced63 11. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000163cffce 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013b9f869 13. /build/src/DataTypes/Serializations/SerializationSparse.cpp:182: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000013c34d19 14. /build/src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000013b9fb5d 15. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000163ccfc4 16. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:59: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000163ccdcc 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x00000000162f3280 18. /build/src/Storages/MergeTree/MergeTreeDataPartWide.cpp:52: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x00000000162ee6be 19. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x00000000163d9d66 20. /build/src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x0000000016d7885f 21. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x0000000016d9cdca 22. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5520 23. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 24. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 25. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 26. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 27. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 28. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 29. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 30. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 31. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:02:44.889147 [ 4591 ] {872cd20f-5da3-4eff-83b7-f1cf2167d335} DNSResolver: Cannot resolve host (localhos), error 0: Host not found. 2025.07.13 02:02:44.979522 [ 5081 ] {a5249951-438b-4dd3-8d24-1cf3e316693b} ExternalDictionariesLoader: Could not load external dictionary '8c70b7c0-abba-472a-988a-69b045663ece', next update is scheduled at 2025-07-13 02:02:50: Code: 482. DB::Exception: Dictionaries with executable dictionary source are not allowed to be created from DDL query. (DICTIONARY_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Dictionaries/ExecutableDictionarySource.cpp:233: std::shared_ptr std::__function::__policy_invoker (DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr, String const&, bool)>::__call_impl[abi:se190107] (DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr, String const&, bool)>>(std::__function::__policy_storage const*, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr&&, String const&, bool) @ 0x00000000119c8c6b 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012c76e33 6. /build/src/Dictionaries/DictionaryFactory.cpp:47: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x0000000012c74a2d 7. /build/src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000147cade4 8. /build/src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000147d6c48 9. /build/src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000147d56dd 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000147d96f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000147d64cd 5. /build/src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000147d465c 6. /build/src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x00000000147e47a8 7. /build/contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&) @ 0x00000000147e445c 8. /build/src/Interpreters/ExternalLoader.cpp:604: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000147d0b9f 9. /build/src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000147d0e15 10. /build/src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000147cb768 11. /build/src/Functions/FunctionsExternalDictionaries.h:76: DB::FunctionDictHelper::getDictionary(String const&) @ 0x000000000a11476c 12. /build/src/Functions/FunctionsExternalDictionaries.h:426: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a11185e 13. /build/src/Functions/FunctionsExternalDictionaries.h:831: DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a12d422 14. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 15. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 16. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 17. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 18. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 19. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 20. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 27. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 28. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 32. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 33. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 34. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 35. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 36. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 37. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 38. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 39. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 40. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 41. ? @ 0x00007f7210eb6ac3 42. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:02:45.008832 [ 6168 ] {a5249951-438b-4dd3-8d24-1cf3e316693b} executeQuery: Code: 482. DB::Exception: Dictionaries with executable dictionary source are not allowed to be created from DDL query: In scope SELECT dictGetString(concat('test_1', '.restricted_dict'), 'value', toUInt64(1)). (DICTIONARY_ACCESS_DENIED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43464) (comment: 01045_dictionaries_restrictions.sql) (query 2, line 11) (in query: SELECT dictGetString(concat('test_1', '.restricted_dict'), 'value', toUInt64(1))), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Dictionaries/ExecutableDictionarySource.cpp:233: std::shared_ptr std::__function::__policy_invoker (DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr, String const&, bool)>::__call_impl[abi:se190107] (DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr, String const&, bool)>>(std::__function::__policy_storage const*, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr&&, String const&, bool) @ 0x00000000119c8c6b 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012c76e33 6. /build/src/Dictionaries/DictionaryFactory.cpp:47: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x0000000012c74a2d 7. /build/src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000147cade4 8. /build/src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000147d6c48 9. /build/src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000147d56dd 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000147d96f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:02:45.022018 [ 6168 ] {} TCPHandler: Code: 482. DB::Exception: Dictionaries with executable dictionary source are not allowed to be created from DDL query: In scope SELECT dictGetString(concat('test_1', '.restricted_dict'), 'value', toUInt64(1)). (DICTIONARY_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Dictionaries/ExecutableDictionarySource.cpp:233: std::shared_ptr std::__function::__policy_invoker (DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr, String const&, bool)>::__call_impl[abi:se190107] (DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr, String const&, bool)>>(std::__function::__policy_storage const*, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr&&, String const&, bool) @ 0x00000000119c8c6b 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012c76e33 6. /build/src/Dictionaries/DictionaryFactory.cpp:47: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x0000000012c74a2d 7. /build/src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000147cade4 8. /build/src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000147d6c48 9. /build/src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000147d56dd 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000147d96f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000147d64cd 5. /build/src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000147d465c 6. /build/src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x00000000147e47a8 7. /build/contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&) @ 0x00000000147e445c 8. /build/src/Interpreters/ExternalLoader.cpp:604: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000147d0b9f 9. /build/src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000147d0e15 10. /build/src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000147cb768 11. /build/src/Functions/FunctionsExternalDictionaries.h:76: DB::FunctionDictHelper::getDictionary(String const&) @ 0x000000000a11476c 12. /build/src/Functions/FunctionsExternalDictionaries.h:426: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a11185e 13. /build/src/Functions/FunctionsExternalDictionaries.h:831: DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a12d422 14. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 15. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 16. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 17. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 18. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 19. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 20. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 27. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 28. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 32. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 33. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 34. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 35. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 36. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 37. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 38. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 39. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 40. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 41. ? @ 0x00007f7210eb6ac3 42. ? @ 0x00007f7210f48850 2025.07.13 02:02:45.085579 [ 6619 ] {82bd9f36-6e0b-41a7-b2aa-60bae1e19e5b} 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]:56014) (comment: 02889_parts_columns_filenames.sql) (in query: DROP DATABASE IF EXISTS test_05p4d2yq SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:02:45.092940 [ 6619 ] {82bd9f36-6e0b-41a7-b2aa-60bae1e19e5b} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:02:51.409586 [ 6619 ] {417ce2c2-1022-4ebd-818f-4c5cef943533} executeQuery: Code: 264. DB::Exception: Table test_7.test_join (ff5f0eb7-4cfd-4126-b577-4f63ec0194ca) needs the same join_use_nulls setting as present in LEFT or FULL JOIN. (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43562) (comment: 03062_analyzer_join_engine_missing_column.sql) (query 7, line 13) (in query: select * from test any left join test_join using (TOPIC, PARTITION);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/StorageJoin.cpp:248: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x0000000015ce357c 5. /build/src/Planner/PlannerJoins.cpp:1244: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x00000000148e410e 6. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0e7d2 7. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 8. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 9. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 14. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 15. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 20. ? @ 0x00007f7210eb6ac3 21. ? @ 0x00007f7210f48850 2025.07.13 02:02:51.420006 [ 6619 ] {} TCPHandler: Code: 264. DB::Exception: Table test_7.test_join (ff5f0eb7-4cfd-4126-b577-4f63ec0194ca) needs the same join_use_nulls setting as present in LEFT or FULL JOIN. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/StorageJoin.cpp:248: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x0000000015ce357c 5. /build/src/Planner/PlannerJoins.cpp:1244: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x00000000148e410e 6. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0e7d2 7. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 8. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 9. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 14. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 15. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 20. ? @ 0x00007f7210eb6ac3 21. ? @ 0x00007f7210f48850 2025.07.13 02:02:51.953328 [ 5117 ] {85e14ed4-f3bb-4e28-9998-45db29be975a} executeQuery: Code: 386. DB::Exception: There is no supertype for types Tuple(Array(UInt8), UInt8), Tuple(Array(UInt8), UInt8, String, String, UInt8) because Tuples have different sizes: In scope SELECT if(xxx = 'x', ([2], 3), ([3], 4, 'q', 'w', 7)) FROM agg_table. (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60236) (comment: 01701_if_tuple_segfault.sql) (query 6, line 21) (in query: SELECT if(xxx = 'x', ([2], 3), ([3], 4, 'q', 'w', 7)) FROM agg_table;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000dda78ab 4. /build/src/DataTypes/getLeastSupertype.cpp:69: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x0000000013b8f59e 5. /build/src/DataTypes/getLeastSupertype.cpp:387: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000013b92aed 6. /build/src/Functions/if.cpp:1206: DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000013fd8f6a 7. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 9. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 25. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 26. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 31. ? @ 0x00007f7210eb6ac3 2025.07.13 02:02:52.015704 [ 5117 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Tuple(Array(UInt8), UInt8), Tuple(Array(UInt8), UInt8, String, String, UInt8) because Tuples have different sizes: In scope SELECT if(xxx = 'x', ([2], 3), ([3], 4, 'q', 'w', 7)) FROM agg_table. (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000dda78ab 4. /build/src/DataTypes/getLeastSupertype.cpp:69: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x0000000013b8f59e 5. /build/src/DataTypes/getLeastSupertype.cpp:387: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000013b92aed 6. /build/src/Functions/if.cpp:1206: DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000013fd8f6a 7. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 9. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 25. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 26. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 31. ? @ 0x00007f7210eb6ac3 2025.07.13 02:02:52.103303 [ 6612 ] {ed230700-cbcd-422a-a685-3c2de105281d} executeQuery: Code: 36. DB::Exception: Function icebergTruncate accepts only positive width: In scope SELECT icebergTruncate(0, 55). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43430) (comment: 03376_iceberg_truncate.sql) (query 37, line 45) (in query: SELECT icebergTruncate(0, 55);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/icebergTruncate.cpp:121: DB::(anonymous namespace)::FunctionIcebergTruncate::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c16ed59 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:02:52.143259 [ 6612 ] {} TCPHandler: Code: 36. DB::Exception: Function icebergTruncate accepts only positive width: In scope SELECT icebergTruncate(0, 55). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/icebergTruncate.cpp:121: DB::(anonymous namespace)::FunctionIcebergTruncate::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c16ed59 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:02:52.448539 [ 6612 ] {e7c89946-435c-4938-bbc8-4636e0bf9c22} executeQuery: Code: 43. DB::Exception: First argument should be UInt data type: In scope SELECT icebergTruncate(-1, 55). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43430) (comment: 03376_iceberg_truncate.sql) (query 38, line 46) (in query: SELECT icebergTruncate(-1, 55);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/icebergTruncate.cpp:73: DB::(anonymous namespace)::FunctionIcebergTruncate::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000c1700a5 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:02:52.478189 [ 6612 ] {} TCPHandler: Code: 43. DB::Exception: First argument should be UInt data type: In scope SELECT icebergTruncate(-1, 55). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/icebergTruncate.cpp:73: DB::(anonymous namespace)::FunctionIcebergTruncate::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000c1700a5 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:02:52.777406 [ 6612 ] {11da8534-9218-48a0-b1a2-632b383b93a5} executeQuery: Code: 43. DB::Exception: Second argument must be of native integer type, String/FixedString, Decimal: In scope SELECT icebergTruncate(3, 0.). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43430) (comment: 03376_iceberg_truncate.sql) (query 39, line 47) (in query: SELECT icebergTruncate(3, 0.0);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/icebergTruncate.cpp:78: DB::(anonymous namespace)::FunctionIcebergTruncate::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000c170123 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:02:52.801437 [ 6612 ] {} TCPHandler: Code: 43. DB::Exception: Second argument must be of native integer type, String/FixedString, Decimal: In scope SELECT icebergTruncate(3, 0.). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/icebergTruncate.cpp:78: DB::(anonymous namespace)::FunctionIcebergTruncate::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000c170123 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:02:52.920356 [ 3768 ] {} DNSResolver: Cannot resolve host (localhos), error 0: Host not found. 2025.07.13 02:02:53.014754 [ 6532 ] {872cd20f-5da3-4eff-83b7-f1cf2167d335} executeQuery: Code: 279. DB::Exception: All connection tries failed. Log: Code: 198. DB::NetException: Not found address of host: localhos: (localhos:9000). (DNS_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]:39222) (comment: 00965_shard_unresolvable_addresses.sql) (query 5, line 9) (in query: SELECT count() FROM remote('127.0.0.1,localhos', system.one);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000015f79f49 3. /build/src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x0000000016723d86 4. /build/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) @ 0x000000001671b5c5 5. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107] 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&) @ 0x0000000013ae898d 6. /build/src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:se190107] 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&&) @ 0x0000000013ae2fc3 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013adb725 8. /build/src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000013af71c3 9. /build/src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013af6952 10. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013af679a 11. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013af64e1 2025.07.13 02:02:53.069314 [ 6532 ] {} TCPHandler: Code: 279. DB::Exception: All connection tries failed. Log: Code: 198. DB::NetException: Not found address of host: localhos: (localhos:9000). (DNS_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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000015f79f49 3. /build/src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x0000000016723d86 4. /build/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) @ 0x000000001671b5c5 5. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107] 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&) @ 0x0000000013ae898d 6. /build/src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:se190107] 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&&) @ 0x0000000013ae2fc3 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013adb725 8. /build/src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000013af71c3 9. /build/src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013af6952 10. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013af679a 11. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013af64e1 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:02:53.335804 [ 6614 ] {535ba6b3-d6ad-45fb-ba7c-6a96496000f4} executeQuery: Code: 691. DB::Exception: Unknown element 'Helo' for enum, maybe you meant: ['Hello']: In scope SELECT CAST('Helo', 'Enum(\'Hello\' = 1, \'World\' = 2)'). (UNKNOWN_ELEMENT_OF_ENUM) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40602) (comment: 01852_hints_enum_name.sh) (query 1, line 1) (in query: SELECT CAST('Helo' AS Enum('Hello' = 1, 'World' = 2))), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000b1f7c4b 4. /build/src/DataTypes/EnumValues.cpp:72: DB::EnumValues<_BitInt(8)>::getValue(StringRef) const @ 0x0000000013b617b2 5. /build/src/Functions/FunctionsConversion.h:5621: 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 @ 0x0000000012e5fb36 6. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::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) @ 0x0000000012e5f8d2 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012cc745b 8. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fc534a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 12. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f75b 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 28. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 29. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 2025.07.13 02:02:53.371539 [ 6614 ] {} TCPHandler: Code: 691. DB::Exception: Unknown element 'Helo' for enum, maybe you meant: ['Hello']: In scope SELECT CAST('Helo', 'Enum(\'Hello\' = 1, \'World\' = 2)'). (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000b1f7c4b 4. /build/src/DataTypes/EnumValues.cpp:72: DB::EnumValues<_BitInt(8)>::getValue(StringRef) const @ 0x0000000013b617b2 5. /build/src/Functions/FunctionsConversion.h:5621: 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 @ 0x0000000012e5fb36 6. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::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) @ 0x0000000012e5f8d2 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012cc745b 8. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fc534a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 12. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f75b 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 28. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 29. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 2025.07.13 02:02:55.422257 [ 6611 ] {7352de6a-89a7-463e-818c-898e2d4fc262} executeQuery: Code: 43. DB::Exception: Illegal type Array(Variant(Tuple(UInt8, UInt8))) expression, must be numeric type. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40636) (comment: 03203_variant_convert_field_to_type_bug.sql) (query 3, line 4) (in query: SELECT * FROM numbers([tuple(1, 2), NULL], 2);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/TableFunctions/TableFunctionNumbers.cpp:105: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x000000001170e12b 5. /build/src/TableFunctions/TableFunctionNumbers.cpp:79: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000001170d2af 6. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000130d4903 7. /build/src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000143537f2 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3da49 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:02:55.462635 [ 6611 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Variant(Tuple(UInt8, UInt8))) expression, must be numeric type. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/TableFunctions/TableFunctionNumbers.cpp:105: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x000000001170e12b 5. /build/src/TableFunctions/TableFunctionNumbers.cpp:79: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000001170d2af 6. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000130d4903 7. /build/src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000143537f2 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3da49 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:02:58.789589 [ 4879 ] {891c494f-25da-465c-93c1-fff8a4e9894e} executeQuery: Code: 36. DB::Exception: Path must be inside user-files path: /var/lib/clickhouse/user_files. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40654) (comment: 02921_database_filesystem_path_check.sql) (query 1, line 1) (in query: create database db_filesystem ENGINE=Filesystem('/etc');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Databases/DatabaseFilesystem.cpp:56: DB::DatabaseFilesystem::DatabaseFilesystem(String const&, String const&, std::shared_ptr) @ 0x0000000013c87a7e 5. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], String const&, String&, std::shared_ptr&, 0>(std::allocator const&, String const&, String&, std::shared_ptr&) @ 0x0000000013c8ad58 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::DatabaseFactory::Arguments const&)>::__call_impl[abi:se190107] (DB::DatabaseFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::DatabaseFactory::Arguments const&) @ 0x0000000013c89e78 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c85a56 8. /build/src/Databases/DatabaseFactory.cpp:111: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x0000000013c854a1 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:341: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014806dae 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:02:58.799681 [ 4879 ] {} TCPHandler: Code: 36. DB::Exception: Path must be inside user-files path: /var/lib/clickhouse/user_files. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Databases/DatabaseFilesystem.cpp:56: DB::DatabaseFilesystem::DatabaseFilesystem(String const&, String const&, std::shared_ptr) @ 0x0000000013c87a7e 5. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], String const&, String&, std::shared_ptr&, 0>(std::allocator const&, String const&, String&, std::shared_ptr&) @ 0x0000000013c8ad58 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::DatabaseFactory::Arguments const&)>::__call_impl[abi:se190107] (DB::DatabaseFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::DatabaseFactory::Arguments const&) @ 0x0000000013c89e78 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c85a56 8. /build/src/Databases/DatabaseFactory.cpp:111: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x0000000013c854a1 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:341: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014806dae 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:02:58.925995 [ 4879 ] {3ad2cbbd-22e4-4792-aaa3-0389dedaecf1} executeQuery: Code: 36. DB::Exception: Path must be inside user-files path: /var/lib/clickhouse/user_files. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40654) (comment: 02921_database_filesystem_path_check.sql) (query 2, line 2) (in query: create database db_filesystem ENGINE=Filesystem('../../../../../../../../etc');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Databases/DatabaseFilesystem.cpp:56: DB::DatabaseFilesystem::DatabaseFilesystem(String const&, String const&, std::shared_ptr) @ 0x0000000013c87a7e 5. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], String const&, String&, std::shared_ptr&, 0>(std::allocator const&, String const&, String&, std::shared_ptr&) @ 0x0000000013c8ad58 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::DatabaseFactory::Arguments const&)>::__call_impl[abi:se190107] (DB::DatabaseFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::DatabaseFactory::Arguments const&) @ 0x0000000013c89e78 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c85a56 8. /build/src/Databases/DatabaseFactory.cpp:111: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x0000000013c854a1 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:341: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014806dae 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:02:58.952709 [ 4879 ] {} TCPHandler: Code: 36. DB::Exception: Path must be inside user-files path: /var/lib/clickhouse/user_files. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Databases/DatabaseFilesystem.cpp:56: DB::DatabaseFilesystem::DatabaseFilesystem(String const&, String const&, std::shared_ptr) @ 0x0000000013c87a7e 5. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], String const&, String&, std::shared_ptr&, 0>(std::allocator const&, String const&, String&, std::shared_ptr&) @ 0x0000000013c8ad58 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::DatabaseFactory::Arguments const&)>::__call_impl[abi:se190107] (DB::DatabaseFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::DatabaseFactory::Arguments const&) @ 0x0000000013c89e78 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c85a56 8. /build/src/Databases/DatabaseFactory.cpp:111: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x0000000013c854a1 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:341: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014806dae 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:02:59.777085 [ 4870 ] {c32ca373-124d-40a2-8b53-83b6123aa5f1} PushingToViews: Failed to push block to view test_7.mview (827856b2-0979-4c5c-89fc-b66a024f0d41), Unknown expression identifier `n` in scope SELECT n, n * n AS n2 FROM test_7.test_table 2025.07.13 02:03:00.006232 [ 4870 ] {c32ca373-124d-40a2-8b53-83b6123aa5f1} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `n` in scope SELECT n, n * n AS n2 FROM test_7.test_table. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39466) (comment: 02789_set_index_nullable_condition_bug.sql) (query 2, line 2) (in query: CREATE TABLE test_table (`col1` String, `col2` String, INDEX test_table_col2_idx col2 TYPE set(0) GRANULARITY 1) ENGINE = MergeTree ORDER BY col1 SETTINGS index_granularity = 61272, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.7837449908256531, 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 = 143928383, compact_parts_max_granules_to_buffer = 211, compact_parts_merge_max_bytes_to_prefetch_part = 4941917, merge_max_block_size = 12843, old_parts_lifetime = 104., prefer_fetch_merged_part_size_threshold = 390277461, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1665795958, index_granularity_bytes = 11377651, 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 = 87651, primary_key_compress_block_size = 49898, use_primary_key_cache = false, prewarm_primary_key_cache = true, prewarm_mark_cache = false AS SELECT 'v1', 'v2'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000013f69e39 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f3a889 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001489281b 14. /build/src/Processors/Transforms/buildPushingToViewsChain.cpp:352: DB::generateViewChain(std::shared_ptr, unsigned long, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x0000000016bd4539 15. /build/src/Processors/Transforms/buildPushingToViewsChain.cpp:530: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000016bd8431 16. /build/src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000001484c2eb 17. /build/src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000001484dcd2 18. /build/src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001484f48c 19. /build/src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001485221d 20. /build/src/Interpreters/InterpreterCreateQuery.cpp:2218: DB::InterpreterCreateQuery::fillTableIfNeeded(DB::ASTCreateQuery const&) @ 0x0000000014821c6c 21. /build/src/Interpreters/InterpreterCreateQuery.cpp:1751: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000001481811f 22. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 23. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 25. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 26. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 31. ? @ 0x00007f7210eb6ac3 2025.07.13 02:03:00.075857 [ 4870 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `n` in scope SELECT n, n * n AS n2 FROM test_7.test_table. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000013f69e39 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f3a889 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001489281b 14. /build/src/Processors/Transforms/buildPushingToViewsChain.cpp:352: DB::generateViewChain(std::shared_ptr, unsigned long, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x0000000016bd4539 15. /build/src/Processors/Transforms/buildPushingToViewsChain.cpp:530: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000016bd8431 16. /build/src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000001484c2eb 17. /build/src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000001484dcd2 18. /build/src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001484f48c 19. /build/src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001485221d 20. /build/src/Interpreters/InterpreterCreateQuery.cpp:2218: DB::InterpreterCreateQuery::fillTableIfNeeded(DB::ASTCreateQuery const&) @ 0x0000000014821c6c 21. /build/src/Interpreters/InterpreterCreateQuery.cpp:1751: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000001481811f 22. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 23. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 25. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 26. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 31. ? @ 0x00007f7210eb6ac3 2025.07.13 02:03:01.202547 [ 6532 ] {4471b349-0ebe-49f9-ab13-9b915accdf65} DNSResolver: Cannot resolve host (localhos), error 0: Host not found. 2025.07.13 02:03:01.324045 [ 6532 ] {4471b349-0ebe-49f9-ab13-9b915accdf65} Cluster: Code: 198. DB::NetException: Not found address of host: localhos. (DNS_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000fa99429 3. /build/src/Common/DNSResolver.cpp:113: DB::(anonymous namespace)::hostByName(String const&) @ 0x000000000fa9670f 4. /build/src/Common/DNSResolver.cpp:138: DB::DNSResolver::getResolvedIPAdressessWithFiltering(String const&) @ 0x000000000fa95228 5. /build/src/Common/DNSResolver.cpp:256: DB::DNSResolver::resolveIPAddressWithCache(String const&) @ 0x000000000fa9554c 6. /build/src/Common/DNSResolver.cpp:305: DB::DNSResolver::resolveAddress(String const&, unsigned short) @ 0x000000000fa96233 7. /build/src/Interpreters/Cluster.cpp:82: DB::Cluster::Address::getResolvedAddress() const @ 0x000000001431b9e5 8. /build/src/Interpreters/Cluster.cpp:95: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x000000001431cb0d 9. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Cluster::Address* std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x000000001432a240 10. /build/contrib/llvm-project/libcxx/include/vector:1558: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x0000000014324471 11. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000011701407 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3bbcc 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:03:03.539696 [ 6168 ] {2020920a-8c9c-4105-936f-7f589bf858b2} 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]:39582) (comment: 01825_type_json_2.sql) (query 1, line 3) (in query: SET allow_experimental_object_type = 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:03:03.569183 [ 6168 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:03:05.167096 [ 5121 ] {68da1f3b-856c-4511-86c4-0d26fe8a4f9a} 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]:39158) (comment: 02915_analyzer_fuzz_6.sql) (in query: DROP DATABASE IF EXISTS test_0t980c1c SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:03:05.170551 [ 5121 ] {68da1f3b-856c-4511-86c4-0d26fe8a4f9a} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:03:08.355209 [ 6615 ] {ab830eb3-1625-47b1-b3dd-4952d749f742} executeQuery: Code: 36. DB::Exception: CellId is invalid.: In scope SELECT s2ToGeo(toUInt64(-1)). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39518) (comment: 01849_geoToS2.sql) (query 26, line 45) (in query: SELECT s2ToGeo(toUInt64(-1));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/s2ToGeo.cpp:100: DB::(anonymous namespace)::FunctionS2ToGeo::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e58ce1d 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:03:08.382187 [ 6615 ] {} TCPHandler: Code: 36. DB::Exception: CellId is invalid.: In scope SELECT s2ToGeo(toUInt64(-1)). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/s2ToGeo.cpp:100: DB::(anonymous namespace)::FunctionS2ToGeo::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e58ce1d 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:03:08.751773 [ 6615 ] {2f435848-882e-446d-8383-12172097b284} executeQuery: Code: 43. DB::Exception: Illegal type Float64 of argument 1 of function s2ToGeo. Must be UInt64: In scope SELECT s2ToGeo(nan). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39518) (comment: 01849_geoToS2.sql) (query 27, line 46) (in query: SELECT s2ToGeo(nan);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, int&&, String&&) @ 0x000000000b96964b 4. /build/src/Functions/s2ToGeo.cpp:59: DB::(anonymous namespace)::FunctionS2ToGeo::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000e58d465 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:03:08.785130 [ 6615 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Float64 of argument 1 of function s2ToGeo. Must be UInt64: In scope SELECT s2ToGeo(nan). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, int&&, String&&) @ 0x000000000b96964b 4. /build/src/Functions/s2ToGeo.cpp:59: DB::(anonymous namespace)::FunctionS2ToGeo::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000e58d465 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:03:09.032033 [ 6615 ] {e5174527-122b-4968-b0b9-a785f0d23b94} executeQuery: Code: 36. DB::Exception: Point (1.8446744073709552e+19, 1.8446744073709552e+19) is invalid in function geoToS2. For valid point the latitude is between -90 and 90 degrees inclusiveand the longitude is between -180 and 180 degrees inclusive.: In scope SELECT geoToS2(toFloat64(toUInt64(-1)), toFloat64(toUInt64(-1))). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39518) (comment: 01849_geoToS2.sql) (query 28, line 47) (in query: SELECT geoToS2(toFloat64(toUInt64(-1)), toFloat64(toUInt64(-1)));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, double const&, double const&, String&&) @ 0x000000000b96bbcb 4. /build/src/Functions/geoToS2.cpp:131: DB::(anonymous namespace)::FunctionGeoToS2::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b96b645 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:03:09.048907 [ 6615 ] {} TCPHandler: Code: 36. DB::Exception: Point (1.8446744073709552e+19, 1.8446744073709552e+19) is invalid in function geoToS2. For valid point the latitude is between -90 and 90 degrees inclusiveand the longitude is between -180 and 180 degrees inclusive.: In scope SELECT geoToS2(toFloat64(toUInt64(-1)), toFloat64(toUInt64(-1))). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, double const&, double const&, String&&) @ 0x000000000b96bbcb 4. /build/src/Functions/geoToS2.cpp:131: DB::(anonymous namespace)::FunctionGeoToS2::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b96b645 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:03:09.245993 [ 6615 ] {d1f0d742-8cf1-41b0-b27e-82e533b016d3} executeQuery: Code: 43. DB::Exception: Illegal argument for longitude in function geoToS2. It must not be NaN: In scope SELECT geoToS2(nan, nan). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39518) (comment: 01849_geoToS2.sql) (query 29, line 48) (in query: SELECT geoToS2(nan, nan);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/geoToS2.cpp:110: DB::(anonymous namespace)::FunctionGeoToS2::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b96b39e 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:03:09.277011 [ 6615 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument for longitude in function geoToS2. It must not be NaN: In scope SELECT geoToS2(nan, nan). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/geoToS2.cpp:110: DB::(anonymous namespace)::FunctionGeoToS2::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b96b39e 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:03:09.681589 [ 6615 ] {3a5c0066-bb1c-4842-a81f-5caeddb56cc4} executeQuery: Code: 43. DB::Exception: Illegal argument for longitude in function geoToS2. It must not be infinite: In scope SELECT geoToS2(-inf, 1.1754943508222875e-38). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39518) (comment: 01849_geoToS2.sql) (query 30, line 49) (in query: SELECT geoToS2(-inf, 1.1754943508222875e-38);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/geoToS2.cpp:113: DB::(anonymous namespace)::FunctionGeoToS2::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b96b43d 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:03:09.727519 [ 6615 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument for longitude in function geoToS2. It must not be infinite: In scope SELECT geoToS2(-inf, 1.1754943508222875e-38). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/geoToS2.cpp:113: DB::(anonymous namespace)::FunctionGeoToS2::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b96b43d 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:03:11.707289 [ 6608 ] {186fc0a1-264a-4a04-aa2b-9c823756768d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=8, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40558) (comment: 00623_in_partition_key.sql) (query 57, line 66) (in query: select 421 from test54378 where part_date = toDate('2018-04-19');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x00000000163993d1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016396620 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001639641f 10. /build/src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000163b2bd7 11. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x00000000162ea22d 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x00000000162e6974 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x00000000163d9d66 14. /build/src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x0000000016d7885f 15. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x0000000016d9cdca 16. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5520 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 18. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 22. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 23. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:03:11.740600 [ 6608 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=8, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x00000000163993d1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016396620 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001639641f 10. /build/src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000163b2bd7 11. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x00000000162ea22d 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x00000000162e6974 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x00000000163d9d66 14. /build/src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x0000000016d7885f 15. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x0000000016d9cdca 16. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5520 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 18. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 22. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 23. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:03:11.920055 [ 6611 ] {d5594c71-282a-49c6-9d30-540498100879} 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]:35344) (comment: 00623_in_partition_key.sql) (in query: DROP DATABASE IF EXISTS test_7f93udcd SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:03:11.948680 [ 6611 ] {d5594c71-282a-49c6-9d30-540498100879} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:03:14.291927 [ 6532 ] {441d8581-ed9d-440a-a444-bf225f9c4ff8} executeQuery: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36220) (query 1, line 1) (in query: select _path,_file from file('nonexist.txt', 'CSV', 'val1 char')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Storages/StorageFile.cpp:1630: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000015caf8eb 5. /build/src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000148b600e 6. /build/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&) @ 0x00000000148ad029 7. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 8. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 10. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:03:14.321566 [ 6532 ] {} TCPHandler: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Storages/StorageFile.cpp:1630: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000015caf8eb 5. /build/src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000148b600e 6. /build/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&) @ 0x00000000148ad029 7. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 8. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 10. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:03:15.536975 [ 4896 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000013779f8b 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000137794b8 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778bc3 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678d325 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:03:16.010422 [ 4008 ] {} DNSResolver: Cannot resolve host (localhos), error 0: Host not found. 2025.07.13 02:03:16.326121 [ 6168 ] {4c22d943-506c-4262-8ecf-095ea8c2d9e1} executeQuery: Code: 184. DB::Exception: Nested identical combinator 'If' is not supported. (ILLEGAL_AGGREGATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36248) (comment: 02025_nested_func_for_if_combinator.sql) (query 3, line 4) (in query: SELECT uniqCombinedIfMergeIf(n, last > 50) FILTER(WHERE last>50) FROM (SELECT uniqCombinedIfState(number, number % 2) AS n, max(number) AS last FROM numbers(10));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:245: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000130cb0fa 5. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:03:16.353052 [ 6168 ] {} TCPHandler: Code: 184. DB::Exception: Nested identical combinator 'If' is not supported. (ILLEGAL_AGGREGATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:245: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000130cb0fa 5. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:03:22.398312 [ 4278 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {79e989a3-28e6-4868-84fc-6251e7368e89::202507_1_86_17}: Code: 241. DB::Exception: Thread memory tracker: fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000000fb2dc4b 4. /build/src/Common/MemoryTracker.cpp:196: MemoryTracker::injectFault() const @ 0x000000000fb2b6cd 5. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:153: DB::MergePlainMergeTreeTask::finish() @ 0x0000000016593639 6. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:72: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000016592af2 7. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 8. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:03:23.085644 [ 6168 ] {2404ee46-091f-4651-ae72-59399b240f7f} executeQuery: Code: 184. DB::Exception: Nested identical combinator 'If' is not supported. (ILLEGAL_AGGREGATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36248) (comment: 02025_nested_func_for_if_combinator.sql) (query 6, line 7) (in query: SELECT uniqCombinedIfMergeIfIf(n, last > 5) FROM (SELECT uniqCombinedIfState(number, number % 2) AS n, max(number) AS last FROM numbers(10));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:245: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000130cb0fa 5. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:03:23.102640 [ 6168 ] {} TCPHandler: Code: 184. DB::Exception: Nested identical combinator 'If' is not supported. (ILLEGAL_AGGREGATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:245: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000130cb0fa 5. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:03:23.246846 [ 6168 ] {f62f6771-c6f3-4a01-a29f-98cf7c5b981b} executeQuery: Code: 184. DB::Exception: Nested identical combinator 'If' is not supported. (ILLEGAL_AGGREGATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36248) (comment: 02025_nested_func_for_if_combinator.sql) (query 7, line 8) (in query: SELECT uniqCombinedIfMergeIfIf(n, last > 5, 1) FROM (SELECT uniqCombinedIfState(number, number % 2) AS n, max(number) AS last FROM numbers(10));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:245: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000130cb0fa 5. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:03:23.299087 [ 6168 ] {} TCPHandler: Code: 184. DB::Exception: Nested identical combinator 'If' is not supported. (ILLEGAL_AGGREGATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:245: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000130cb0fa 5. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:03:24.161552 [ 3542 ] {a7b4f785-9152-43a5-9063-7374e386a9a6} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `Y` in scope SELECT * FROM (SELECT [1, 2, 3] AS x, [4, 5, 6] AS y) ARRAY JOIN x, Y. Maybe you meant: ['y']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43806) (comment: 03071_analyzer_array_join_forbid_non_existing_columns.sql) (query 2, line 3) (in query: SELECT * FROM ( SELECT [1, 2, 3] AS x, [4, 5, 6] AS y ) ARRAY JOIN x, Y;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000013f69e39 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f3a889 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5014: DB::QueryAnalyzer::resolveArrayJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f63da3 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5333: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642c7 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:03:24.175961 [ 3542 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `Y` in scope SELECT * FROM (SELECT [1, 2, 3] AS x, [4, 5, 6] AS y) ARRAY JOIN x, Y. Maybe you meant: ['y']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000013f69e39 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f3a889 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5014: DB::QueryAnalyzer::resolveArrayJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f63da3 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5333: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642c7 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:03:25.640481 [ 6615 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000013779f8b 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000137794b8 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778bc3 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678d325 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:03:26.383467 [ 4871 ] {f04818c7-3bc8-43df-bc1b-068802da39aa} 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]:43752) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:562: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0ef83 5. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 6. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 7. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:03:26.418063 [ 4871 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:562: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0ef83 5. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 6. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 7. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:03:26.508053 [ 6532 ] {dd15e6d0-b9b0-4d2a-8b1f-d48aef983560} 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]:43794) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/tupleElement.cpp:63: DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e84c9c4 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:03:26.533629 [ 6532 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/tupleElement.cpp:63: DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e84c9c4 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:03:26.888459 [ 6532 ] {99370bbe-68d1-4fae-8692-917919aab70c} 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]:43794) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000a309b0b 4. /build/src/Functions/tupleElement.cpp:49: DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e84c914 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:03:26.916442 [ 6532 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000a309b0b 4. /build/src/Functions/tupleElement.cpp:49: DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e84c914 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:03:27.296575 [ 6532 ] {c81a5d46-4052-418e-93d1-618fb538ae9b} 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]:43794) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/tupleElement.cpp:151: DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000000e84cfd3 5. /build/src/Functions/tupleElement.cpp:68: DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e84c73f 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:03:27.351049 [ 6532 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/tupleElement.cpp:151: DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000000e84cfd3 5. /build/src/Functions/tupleElement.cpp:68: DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e84c73f 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:03:27.394014 [ 5872 ] {a5acf9f5-b59d-4654-acbe-13ef9ea7f9af} executeQuery: Code: 128. DB::Exception: Too large array size in GenerateRandom: 9223372036854775807, maximum: 1073741824. (TOO_LARGE_ARRAY_SIZE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43904) (comment: 01352_generate_random_overflow.sql) (query 1, line 1) (in query: SELECT i FROM generateRandom('i Array(Nullable(Enum8(\'hello\' = 1, \'world\' = 5)))', 1025, 65535, 9223372036854775807) LIMIT 10;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x000000000a9d8bcb 4. /build/src/Storages/StorageGenerateRandom.cpp:634: DB::StorageGenerateRandom::StorageGenerateRandom(DB::StorageID const&, DB::ColumnsDescription const&, String const&, unsigned long, unsigned long, std::optional const&) @ 0x0000000015cd2053 5. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::StorageID, DB::ColumnsDescription&, String, unsigned long const&, unsigned long const&, std::optional const&, 0>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&, String&&, unsigned long const&, unsigned long const&, std::optional const&) @ 0x000000001172fbab 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionGenerateRandom::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000001172f789 7. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000130d4903 8. /build/src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000143537f2 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3da49 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:03:27.415407 [ 5872 ] {} TCPHandler: Code: 128. DB::Exception: Too large array size in GenerateRandom: 9223372036854775807, maximum: 1073741824. (TOO_LARGE_ARRAY_SIZE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x000000000a9d8bcb 4. /build/src/Storages/StorageGenerateRandom.cpp:634: DB::StorageGenerateRandom::StorageGenerateRandom(DB::StorageID const&, DB::ColumnsDescription const&, String const&, unsigned long, unsigned long, std::optional const&) @ 0x0000000015cd2053 5. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::StorageID, DB::ColumnsDescription&, String, unsigned long const&, unsigned long const&, std::optional const&, 0>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&, String&&, unsigned long const&, unsigned long const&, std::optional const&) @ 0x000000001172fbab 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionGenerateRandom::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000001172f789 7. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000130d4903 8. /build/src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000143537f2 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3da49 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:03:27.544731 [ 4871 ] {df946201-83df-458b-b056-dba4e423cffd} 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]:43938) (comment: 02886_missed_json_subcolumns.sql) (query 2, line 3) (in query: SET allow_experimental_object_type = 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:03:27.599102 [ 4871 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:03:27.963054 [ 6532 ] {aeb8ad87-6949-44e4-8acd-870c60c22751} 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]:43794) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000a8668eb 4. /build/src/Functions/tupleElement.cpp:140: DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000000e84cf35 5. /build/src/Functions/tupleElement.cpp:68: DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e84c73f 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:03:27.997050 [ 6532 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000a8668eb 4. /build/src/Functions/tupleElement.cpp:140: DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000000e84cf35 5. /build/src/Functions/tupleElement.cpp:68: DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e84c73f 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:03:28.220539 [ 6532 ] {b3246acc-f390-4879-b1f0-7dc460055236} 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]:43794) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000a8668eb 4. /build/src/Functions/tupleElement.cpp:140: DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000000e84cf35 5. /build/src/Functions/tupleElement.cpp:68: DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e84c73f 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:03:28.261103 [ 6532 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000a8668eb 4. /build/src/Functions/tupleElement.cpp:140: DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000000e84cf35 5. /build/src/Functions/tupleElement.cpp:68: DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e84c73f 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:03:28.646255 [ 6532 ] {fe8ec4e7-c40d-44a5-8216-a940344973fb} 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]:43794) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/tupleElement.cpp:155: DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000000e84ce94 5. /build/src/Functions/tupleElement.cpp:68: DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e84c73f 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:03:28.659889 [ 6532 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/tupleElement.cpp:155: DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000000e84ce94 5. /build/src/Functions/tupleElement.cpp:68: DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e84c73f 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:03:28.962938 [ 5018 ] {773b3df0-dbff-4673-a9e5-6052d84e6aa8} executeQuery: Code: 62. DB::Exception: When creating a materialized view you can't declare both 'TO [db].[table]' and 'EMPTY'. (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:34912) (comment: 02900_matview_create_to_errors.sh) (in query: create materialized view aaaa TO b EMPTY as Select * from a;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Parsers/ParserCreateQuery.cpp:1690: DB::ParserCreateViewQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001796efd3 5. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 6. /build/src/Parsers/ParserCreateQuery.cpp:1967: DB::ParserCreateQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001797076e 7. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 8. /build/src/Parsers/ParserQueryWithOutput.cpp:86: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001798770f 9. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 10. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 11. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 12. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 13. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 14. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 15. /build/src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba32be 16. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 17. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 18. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 19. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:03:28.966880 [ 5018 ] {773b3df0-dbff-4673-a9e5-6052d84e6aa8} DynamicQueryHandler: Code: 62. DB::Exception: When creating a materialized view you can't declare both 'TO [db].[table]' and 'EMPTY'. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Parsers/ParserCreateQuery.cpp:1690: DB::ParserCreateViewQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001796efd3 5. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 6. /build/src/Parsers/ParserCreateQuery.cpp:1967: DB::ParserCreateQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001797076e 7. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 8. /build/src/Parsers/ParserQueryWithOutput.cpp:86: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001798770f 9. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 10. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 11. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 12. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 13. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 14. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 15. /build/src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba32be 16. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 17. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 18. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 19. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:03:29.042097 [ 5872 ] {97912371-2439-47ed-925a-17df33fb65a1} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=8, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43940) (comment: 01913_quantile_deterministic.sh) (query 1, line 1) (in query: SELECT medianDeterministic(oid, oid) FROM d), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x00000000163993d1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016396620 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001639641f 10. /build/src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000163b2bd7 11. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x00000000162ea22d 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x00000000162e6974 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x00000000163d9d66 14. /build/src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x0000000016d7885f 15. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x0000000016d9cdca 16. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5520 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 18. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 22. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 23. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:03:29.086105 [ 5872 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=8, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x00000000163993d1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016396620 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001639641f 10. /build/src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000163b2bd7 11. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x00000000162ea22d 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x00000000162e6974 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x00000000163d9d66 14. /build/src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x0000000016d7885f 15. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x0000000016d9cdca 16. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5520 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 18. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 22. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 23. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:03:29.499492 [ 3543 ] {36403fc2-620b-49a0-8163-5d51dd6d219d} executeQuery: Code: 60. DB::Exception: Table `test_ysdhcmlw`.`test_ysdhcmlw` doesn't exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43730) (comment: 02891_rename_table_without_keyword.sql) (query 18, line 39) (in query: RENAME TABLE test_ysdhcmlw TO test_ysdhcmlw_1), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x0000000013cf30c0 5. /build/src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000013c7b27c 6. /build/src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x000000001485ae00 7. /build/src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000148599e9 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 10. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:03:29.513793 [ 3543 ] {} TCPHandler: Code: 60. DB::Exception: Table `test_ysdhcmlw`.`test_ysdhcmlw` doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x0000000013cf30c0 5. /build/src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000013c7b27c 6. /build/src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x000000001485ae00 7. /build/src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000148599e9 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 10. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:03:29.551412 [ 6637 ] {ee5271d6-9c83-462c-b9ee-d15fa4e3ee1c} executeQuery: Code: 62. DB::Exception: When creating a materialized view you can't declare both 'TO [db].[table]' and 'POPULATE'. (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:60590) (comment: 02900_matview_create_to_errors.sh) (in query: create materialized view aaaa TO b POPULATE as Select * from a;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Parsers/ParserCreateQuery.cpp:1684: DB::ParserCreateViewQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001796eefd 5. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 6. /build/src/Parsers/ParserCreateQuery.cpp:1967: DB::ParserCreateQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001797076e 7. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 8. /build/src/Parsers/ParserQueryWithOutput.cpp:86: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001798770f 9. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 10. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 11. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 12. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 13. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 14. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 15. /build/src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba32be 16. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 17. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 18. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 19. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:03:29.572940 [ 6637 ] {ee5271d6-9c83-462c-b9ee-d15fa4e3ee1c} DynamicQueryHandler: Code: 62. DB::Exception: When creating a materialized view you can't declare both 'TO [db].[table]' and 'POPULATE'. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Parsers/ParserCreateQuery.cpp:1684: DB::ParserCreateViewQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001796eefd 5. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 6. /build/src/Parsers/ParserCreateQuery.cpp:1967: DB::ParserCreateQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001797076e 7. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 8. /build/src/Parsers/ParserQueryWithOutput.cpp:86: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001798770f 9. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 10. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 11. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 12. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 13. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 14. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 15. /build/src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba32be 16. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 17. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 18. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 19. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:03:29.628304 [ 5018 ] {23f60c1e-24b0-4e3e-8b8a-f2259661fb53} executeQuery: Code: 57. DB::Exception: Table test_15.a already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34262) (comment: 03033_set_index_in.sql) (query 2, line 3) (in query: CREATE TABLE a (`k` UInt64, `v` UInt64, INDEX i v TYPE set(100) GRANULARITY 2) ENGINE = MergeTree ORDER BY k SETTINGS index_granularity = 8192, index_granularity_bytes = 1000000000, min_index_granularity_bytes = 0, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.07564695179462433, replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 120254387, compact_parts_max_bytes_to_buffer = 33635045, compact_parts_max_granules_to_buffer = 14, compact_parts_merge_max_bytes_to_prefetch_part = 18062589, merge_max_block_size = 15301, old_parts_lifetime = 476., 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, 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 = 69732, primary_key_compress_block_size = 32334, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:03:29.674860 [ 5018 ] {} TCPHandler: Code: 57. DB::Exception: Table test_15.a already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:03:29.837916 [ 6612 ] {ba64f5b6-5a04-4e12-b1ec-33bc6fdab796} executeQuery: Code: 62. DB::Exception: When creating a materialized view you can't declare both 'TO [db].[table]' and 'ENGINE'. (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:60594) (comment: 02900_matview_create_to_errors.sh) (in query: create materialized view aaaa TO b ENGINE = MergeTree() as Select * from a;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Parsers/ParserCreateQuery.cpp:1680: DB::ParserCreateViewQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001796ee92 5. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 6. /build/src/Parsers/ParserCreateQuery.cpp:1967: DB::ParserCreateQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001797076e 7. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 8. /build/src/Parsers/ParserQueryWithOutput.cpp:86: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001798770f 9. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 10. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 11. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 12. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 13. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 14. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 15. /build/src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba32be 16. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 17. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 18. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 19. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:03:29.843406 [ 6612 ] {ba64f5b6-5a04-4e12-b1ec-33bc6fdab796} DynamicQueryHandler: Code: 62. DB::Exception: When creating a materialized view you can't declare both 'TO [db].[table]' and 'ENGINE'. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Parsers/ParserCreateQuery.cpp:1680: DB::ParserCreateViewQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001796ee92 5. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 6. /build/src/Parsers/ParserCreateQuery.cpp:1967: DB::ParserCreateQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001797076e 7. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 8. /build/src/Parsers/ParserQueryWithOutput.cpp:86: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001798770f 9. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 10. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 11. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 12. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 13. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 14. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 15. /build/src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba32be 16. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 17. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 18. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 19. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:03:29.999575 [ 6532 ] {8fdf948f-f5a2-4f15-8b78-e2929d918a34} 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]:43794) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000a309b0b 4. /build/src/Functions/tupleElement.cpp:49: DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e84c914 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:03:30.019688 [ 6532 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000a309b0b 4. /build/src/Functions/tupleElement.cpp:49: DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e84c914 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:03:30.130602 [ 6637 ] {9f05f9bd-009a-4a86-b2da-9658f9c7755f} 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]:45416) (comment: 03164_analyzer_validate_tree_size.sql) (in query: DROP DATABASE IF EXISTS test_t808epcj SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:03:30.131944 [ 3543 ] {52db770c-69a6-4a7b-b2eb-f10fe798c520} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43730) (comment: 02891_rename_table_without_keyword.sql) (query 20, line 42) (in query: DROP DATABASE IF EXISTS test_ysdhcmlw), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833ede 5. /build/src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835a47 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:03:30.138582 [ 6637 ] {9f05f9bd-009a-4a86-b2da-9658f9c7755f} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:03:30.163085 [ 3543 ] {} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833ede 5. /build/src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835a47 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:03:30.214876 [ 5018 ] {95aa49ca-322a-4c9c-8f44-7e1da9bceabd} executeQuery: Code: 62. DB::Exception: When creating a materialized view you can't declare both 'ENGINE' and 'TO [db].[table]'. (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:60610) (comment: 02900_matview_create_to_errors.sh) (in query: create materialized view aaaa ENGINE = MergeTree() TO b as Select * from a;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Parsers/ParserCreateQuery.cpp:1674: DB::ParserCreateViewQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001796ef6b 5. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 6. /build/src/Parsers/ParserCreateQuery.cpp:1967: DB::ParserCreateQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001797076e 7. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 8. /build/src/Parsers/ParserQueryWithOutput.cpp:86: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001798770f 9. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 10. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 11. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 12. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 13. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 14. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 15. /build/src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba32be 16. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 17. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 18. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 19. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:03:30.222531 [ 5018 ] {95aa49ca-322a-4c9c-8f44-7e1da9bceabd} DynamicQueryHandler: Code: 62. DB::Exception: When creating a materialized view you can't declare both 'ENGINE' and 'TO [db].[table]'. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Parsers/ParserCreateQuery.cpp:1674: DB::ParserCreateViewQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001796ef6b 5. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 6. /build/src/Parsers/ParserCreateQuery.cpp:1967: DB::ParserCreateQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001797076e 7. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 8. /build/src/Parsers/ParserQueryWithOutput.cpp:86: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001798770f 9. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 10. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 11. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 12. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 13. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 14. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 15. /build/src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba32be 16. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 17. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 18. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 19. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:03:30.259785 [ 6532 ] {2a512ef0-7def-46cc-9d25-78cd58c2568b} 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]:43794) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/tupleElement.cpp:151: DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000000e84cfd3 5. /build/src/Functions/tupleElement.cpp:68: DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e84c73f 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:03:30.271561 [ 6532 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/tupleElement.cpp:151: DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000000e84cfd3 5. /build/src/Functions/tupleElement.cpp:68: DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e84c73f 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:03:30.396056 [ 6532 ] {96d822ba-162a-4103-974e-86cffefee49a} 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]:43794) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000a8668eb 4. /build/src/Functions/tupleElement.cpp:140: DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000000e84cf35 5. /build/src/Functions/tupleElement.cpp:68: DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e84c73f 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:03:30.413430 [ 6532 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000a8668eb 4. /build/src/Functions/tupleElement.cpp:140: DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000000e84cf35 5. /build/src/Functions/tupleElement.cpp:68: DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e84c73f 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:03:30.592564 [ 6532 ] {98d61512-1fac-485b-9e58-6993d78f5117} 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]:43794) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000a8668eb 4. /build/src/Functions/tupleElement.cpp:140: DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000000e84cf35 5. /build/src/Functions/tupleElement.cpp:68: DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e84c73f 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:03:30.639903 [ 6532 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000a8668eb 4. /build/src/Functions/tupleElement.cpp:140: DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000000e84cf35 5. /build/src/Functions/tupleElement.cpp:68: DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e84c73f 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:03:30.988788 [ 6532 ] {a6a7df13-53fa-440b-b168-4869c7e0a963} 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]:43794) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/tupleElement.cpp:155: DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000000e84ce94 5. /build/src/Functions/tupleElement.cpp:68: DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e84c73f 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:03:31.019889 [ 6532 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/tupleElement.cpp:155: DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000000e84ce94 5. /build/src/Functions/tupleElement.cpp:68: DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e84c73f 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:03:33.159239 [ 5121 ] {3e67bdba-ac64-4633-b1a0-81c336872bfa} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=793, jobs=785). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43956) (comment: 03031_distinguish_bool_and_int_in_settings.sql) (query 17, line 28) (in query: SELECT 'custom_t1' AS name, getSetting(name) AS value, toTypeName(value);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbdd1d3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd751c 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 9. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 10. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:03:33.185335 [ 5121 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=793, jobs=785). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbdd1d3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd751c 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 9. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 10. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:03:33.231957 [ 6168 ] {f9d851bc-6cee-43a7-ac17-fedbd405c22f} 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]:34360) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000c4bf5f3 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:03:33.262666 [ 6168 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000c4bf5f3 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:03:33.418182 [ 6168 ] {4c14c3df-38ea-4472-a6bd-1c6fd777ba51} 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]:34360) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000c4bf5f3 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:03:33.515462 [ 6168 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000c4bf5f3 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:03:33.732757 [ 6168 ] {8af0b002-50c2-4ce6-99e9-164d5ac68a2a} 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]:34360) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000c4bf5f3 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:03:33.742029 [ 6168 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000c4bf5f3 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:03:33.961287 [ 6168 ] {b809b23e-74ef-483a-8abe-1a80ceee569e} 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]:34360) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000c4bf5f3 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:03:34.029974 [ 6168 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000c4bf5f3 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:03:34.275844 [ 6168 ] {2d5b61c5-0f56-450b-800e-aa5d7c383390} 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]:34360) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000c4bf5f3 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:03:34.300224 [ 6168 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000c4bf5f3 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:03:36.137996 [ 3543 ] {28bb3da4-3b32-4a5c-8b12-96120e53d635} 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]:45548) (comment: 01913_quantile_deterministic.sh) (in query: DROP DATABASE IF EXISTS test_ueui7bnu SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:03:36.143453 [ 3543 ] {28bb3da4-3b32-4a5c-8b12-96120e53d635} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:03:36.390252 [ 5872 ] {b0ba1636-68e7-4055-af57-657da2575002} 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]:34390) (comment: 02155_dictionary_comment.sql) (query 7, line 22) (in query: ALTER TABLE 02155_test_dictionary COMMENT COLUMN value 'value_column';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::AlterCommand::Type const&, String&&) @ 0x0000000013380c0b 4. /build/src/Storages/StorageDictionary.cpp:303: DB::StorageDictionary::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000015c79a5c 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd033 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:03:36.406556 [ 5872 ] {} TCPHandler: Code: 48. DB::Exception: Alter of type 'COMMENT_COLUMN' is not supported by storage Dictionary. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::AlterCommand::Type const&, String&&) @ 0x0000000013380c0b 4. /build/src/Storages/StorageDictionary.cpp:303: DB::StorageDictionary::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000015c79a5c 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd033 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:03:36.763019 [ 5018 ] {ae8e5811-99c9-4f00-b70e-a282160e2d66} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:60642) (in query: select 1 where 'MUTATE_PART' not in (select type from system.replication_queue where database='test_sl4g3e40' and table='mut') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda7a6 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x0000000016a39e45 8. /build/src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x0000000016a38ffc 9. /build/src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:15: DB::ParallelFormattingOutputFormat::finalizeImpl() @ 0x0000000016a38ac2 10. /build/src/Processors/Formats/IOutputFormat.cpp:165: DB::IOutputFormat::work() @ 0x00000000168e7ee3 11. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 12. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 13. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 14. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 18. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:03:36.876032 [ 5018 ] {ae8e5811-99c9-4f00-b70e-a282160e2d66} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda7a6 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x0000000016a39e45 8. /build/src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x0000000016a38ffc 9. /build/src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:15: DB::ParallelFormattingOutputFormat::finalizeImpl() @ 0x0000000016a38ac2 10. /build/src/Processors/Formats/IOutputFormat.cpp:165: DB::IOutputFormat::work() @ 0x00000000168e7ee3 11. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 12. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 13. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 14. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 18. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000168cfa64 8. /build/src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014bab0a3 9. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:03:37.094161 [ 6619 ] {78746d89-ee9c-4889-b4d8-0f1df707e14c} executeQuery: Code: 48. DB::Exception: Alter of type 'MODIFY_SETTING' is not supported by storage Log. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 00980_merge_alter_settings.sql) (in query: /* ddl_entry=query-0000000003 */ ALTER TABLE test_8zg910xt.log_for_alter (MODIFY SETTING aaa = 123)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::AlterCommand::Type const&, String&&) @ 0x0000000013380c0b 4. /build/src/Storages/IStorage.cpp:243: DB::IStorage::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000015c3d91c 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd033 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 12. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 13. /build/src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fbd85 14. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:03:37.212574 [ 6619 ] {78746d89-ee9c-4889-b4d8-0f1df707e14c} executeQuery: Code: 48. DB::Exception: Alter of type 'MODIFY_SETTING' is not supported by storage Log. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34462) (comment: 00980_merge_alter_settings.sql) (query 3, line 11) (in query: ALTER TABLE log_for_alter MODIFY SETTING aaa=123;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::AlterCommand::Type const&, String&&) @ 0x0000000013380c0b 4. /build/src/Storages/IStorage.cpp:243: DB::IStorage::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000015c3d91c 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd033 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 12. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 13. /build/src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fbd85 14. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:03:37.218692 [ 6619 ] {} TCPHandler: Code: 48. DB::Exception: Alter of type 'MODIFY_SETTING' is not supported by storage Log. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::AlterCommand::Type const&, String&&) @ 0x0000000013380c0b 4. /build/src/Storages/IStorage.cpp:243: DB::IStorage::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000015c3d91c 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd033 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 12. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 13. /build/src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fbd85 14. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:03:37.510236 [ 6168 ] {da26be3d-312b-48e5-a532-ebb83ad3e77b} 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]:34486) (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 = 11717, 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 = 256605160, compact_parts_max_bytes_to_buffer = 441173623, compact_parts_max_granules_to_buffer = 198, compact_parts_merge_max_bytes_to_prefetch_part = 24752371, merge_max_block_size = 5241, old_parts_lifetime = 443., 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 = 1, index_granularity_bytes = 27490125, 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 = 52225, primary_key_compress_block_size = 55506, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:800: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001480fb4b 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000001481759b 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:03:37.525720 [ 6168 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:800: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001480fb4b 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000001481759b 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:03:38.531062 [ 6608 ] {test_5_3351} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 1 (BAD): BAD SQL. 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]:60700) (comment: 02564_query_id_header.sh) (in query: BAD SQL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000009fd29ed 3. /build/src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9acc 4. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 5. /build/src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba32be 6. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 7. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 8. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 9. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:03:38.556323 [ 6608 ] {test_5_3351} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 1 (BAD): BAD SQL. 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000009fd29ed 3. /build/src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9acc 4. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 5. /build/src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba32be 6. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 7. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 8. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 9. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:03:39.047370 [ 3703 ] {} DNSResolver: Cannot resolve host (localhos), error 0: Host not found. 2025.07.13 02:03:39.190978 [ 6611 ] {7695d4b9-f2c8-4b66-aa16-7b4e557159d3} 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_ng39ges2.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]:34428) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x00000000141e22ab 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:601: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x00000000141dc3e7 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141dcb4f 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1349: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141ddd26 7. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000141e1431 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000013f4860b 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f392f4 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:209: DB::QueryTreePassManager::run(std::shared_ptr, unsigned long) @ 0x0000000013f8c914 16. /build/src/Analyzer/QueryTreePassManager.cpp:194: DB::QueryTreePassManager::runOnlyResolve(std::shared_ptr) @ 0x0000000013f8c7c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924a2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/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) @ 0x0000000016cdd4ac 20. /build/src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:169: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool)::$_0::operator()() const @ 0x00000000157d90f1 21. /build/src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:244: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool) @ 0x00000000157d7a84 22. /build/src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:321: DB::ClusterProxy::SelectStreamFactory::createForShard(DB::Cluster::ShardInfo const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>) @ 0x00000000157d9398 23. /build/src/Interpreters/ClusterProxy/executeQuery.cpp:369: DB::ClusterProxy::executeQuery(DB::QueryPlan&, DB::Block const&, DB::QueryProcessingStage::Enum, DB::StorageID const&, std::shared_ptr const&, DB::ClusterProxy::SelectStreamFactory&, std::shared_ptr, std::shared_ptr, DB::SelectQueryInfo const&, std::shared_ptr const&, String const&, DB::DistributedSettings const&, std::function (unsigned long)>, bool) @ 0x00000000157c94a1 24. /build/src/Storages/StorageDistributed.cpp:912: DB::StorageDistributed::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000015c83b3b 25. /build/src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000148b600e 26. /build/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&) @ 0x00000000148ad029 27. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 28. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 30. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 31. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 2025.07.13 02:03:39.213385 [ 6611 ] {} 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_ng39ges2.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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x00000000141e22ab 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:601: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x00000000141dc3e7 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141dcb4f 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1349: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141ddd26 7. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000141e1431 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000013f4860b 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f392f4 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:209: DB::QueryTreePassManager::run(std::shared_ptr, unsigned long) @ 0x0000000013f8c914 16. /build/src/Analyzer/QueryTreePassManager.cpp:194: DB::QueryTreePassManager::runOnlyResolve(std::shared_ptr) @ 0x0000000013f8c7c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924a2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/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) @ 0x0000000016cdd4ac 20. /build/src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:169: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool)::$_0::operator()() const @ 0x00000000157d90f1 21. /build/src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:244: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool) @ 0x00000000157d7a84 22. /build/src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:321: DB::ClusterProxy::SelectStreamFactory::createForShard(DB::Cluster::ShardInfo const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>) @ 0x00000000157d9398 23. /build/src/Interpreters/ClusterProxy/executeQuery.cpp:369: DB::ClusterProxy::executeQuery(DB::QueryPlan&, DB::Block const&, DB::QueryProcessingStage::Enum, DB::StorageID const&, std::shared_ptr const&, DB::ClusterProxy::SelectStreamFactory&, std::shared_ptr, std::shared_ptr, DB::SelectQueryInfo const&, std::shared_ptr const&, String const&, DB::DistributedSettings const&, std::function (unsigned long)>, bool) @ 0x00000000157c94a1 24. /build/src/Storages/StorageDistributed.cpp:912: DB::StorageDistributed::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000015c83b3b 25. /build/src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000148b600e 26. /build/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&) @ 0x00000000148ad029 27. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 28. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 30. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 31. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 2025.07.13 02:03:39.487650 [ 6168 ] {69011f5b-4018-4902-9d81-0d821e627bee} 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]:34486) (comment: 02346_fulltext_index_old_name.sql) (query 8, line 19) (in query: ATTACH TABLE tab;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000118cbf6e 8. /build/src/Storages/MergeTree/MergeTreeData.cpp:1790: DB::MergeTreeData::loadDataPartsFromDisk(std::vector, std::allocator>>&) @ 0x0000000016237606 9. /build/src/Storages/MergeTree/MergeTreeData.cpp:1986: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x000000001623964a 10. /build/src/Storages/StorageMergeTree.cpp:161: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000016556df5 11. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000165568d0 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000165531fd 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ca1a22 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001481ee32 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 16. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 17. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 19. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 20. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 2025.07.13 02:03:39.579977 [ 6168 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000118cbf6e 8. /build/src/Storages/MergeTree/MergeTreeData.cpp:1790: DB::MergeTreeData::loadDataPartsFromDisk(std::vector, std::allocator>>&) @ 0x0000000016237606 9. /build/src/Storages/MergeTree/MergeTreeData.cpp:1986: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x000000001623964a 10. /build/src/Storages/StorageMergeTree.cpp:161: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000016556df5 11. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000165568d0 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000165531fd 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ca1a22 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001481ee32 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 16. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 17. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 19. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 20. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 2025.07.13 02:03:40.017308 [ 5018 ] {a6ee0f30-f00d-4510-baaf-907a9c8ee60f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:60642) (in query: select 1 where 'MUTATE_PART' not in (select type from system.replication_queue where database='test_sl4g3e40' and table='mut') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x0000000016a39e45 8. /build/src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x0000000016a38ffc 9. /build/src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:136: DB::ParallelFormattingOutputFormat::writeSuffix() @ 0x0000000016a3a9fa 10. /build/src/Processors/Formats/IOutputFormat.h:120: DB::IOutputFormat::work() @ 0x00000000168e7ece 11. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 12. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 13. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 14. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 18. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:03:40.131670 [ 5018 ] {a6ee0f30-f00d-4510-baaf-907a9c8ee60f} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x0000000016a39e45 8. /build/src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x0000000016a38ffc 9. /build/src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:136: DB::ParallelFormattingOutputFormat::writeSuffix() @ 0x0000000016a3a9fa 10. /build/src/Processors/Formats/IOutputFormat.h:120: DB::IOutputFormat::work() @ 0x00000000168e7ece 11. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 12. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 13. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 14. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 18. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000168cfa64 8. /build/src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014bab0a3 9. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:03:40.248036 [ 6619 ] {10ef5477-ecd9-46f1-9b36-9b97a0c66176} executeQuery: Code: 472. DB::Exception: Setting 'index_granularity' is readonly for storage 'MergeTree'. (READONLY_SETTING) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 00980_merge_alter_settings.sql) (in query: /* ddl_entry=query-0000000006 */ ALTER TABLE test_8zg910xt.table_for_alter (MODIFY SETTING index_granularity = 555)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3888: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001625b9b3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd033 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 12. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 13. /build/src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fbd85 14. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:03:40.309476 [ 6619 ] {10ef5477-ecd9-46f1-9b36-9b97a0c66176} executeQuery: Code: 472. DB::Exception: Setting 'index_granularity' is readonly for storage 'MergeTree'. (READONLY_SETTING) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34462) (comment: 00980_merge_alter_settings.sql) (query 7, line 22) (in query: ALTER TABLE table_for_alter MODIFY SETTING index_granularity=555;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3888: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001625b9b3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd033 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 12. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 13. /build/src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fbd85 14. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:03:40.323068 [ 6619 ] {} TCPHandler: Code: 472. DB::Exception: Setting 'index_granularity' is readonly for storage 'MergeTree'. (READONLY_SETTING), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3888: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001625b9b3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd033 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 12. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 13. /build/src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fbd85 14. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:03:41.220742 [ 4870 ] {454474db-eb85-4eb3-a430-a8ad7a72e8e2} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 8 ($): $$ab . Expected one of: ALL, DISTINCT ON, DISTINCT, TOP, not empty list of expressions, list of expressions, list of elements, expression with optional alias, element of expression with optional alias, lambda expression, CAST operator, NOT, INTERVAL, CASE, DATE, TIMESTAMP, tuple, collection of literals, array, number, literal, NULL, NULL, Bool, TRUE, FALSE, string literal, asterisk, qualified asterisk, compound identifier, identifier, COLUMNS matcher, COLUMNS, qualified COLUMNS matcher, function name, substitution, MySQL-style global variable. (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:47980) (comment: 01949_heredoc_unfinished.sh) (in query: SELECT $$ab ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000009fd29ed 3. /build/src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9acc 4. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 5. /build/src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba32be 6. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 7. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 8. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 9. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:03:41.230051 [ 4870 ] {454474db-eb85-4eb3-a430-a8ad7a72e8e2} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 8 ($): $$ab . Expected one of: ALL, DISTINCT ON, DISTINCT, TOP, not empty list of expressions, list of expressions, list of elements, expression with optional alias, element of expression with optional alias, lambda expression, CAST operator, NOT, INTERVAL, CASE, DATE, TIMESTAMP, tuple, collection of literals, array, number, literal, NULL, NULL, Bool, TRUE, FALSE, string literal, asterisk, qualified asterisk, compound identifier, identifier, COLUMNS matcher, COLUMNS, qualified COLUMNS matcher, function name, substitution, MySQL-style global variable. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000009fd29ed 3. /build/src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9acc 4. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 5. /build/src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba32be 6. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 7. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 8. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 9. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:03:41.517325 [ 3542 ] {45b0f870-0c23-4bfd-8a0a-61dd4b7cb218} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 8 ($): $$ . Expected one of: ALL, DISTINCT ON, DISTINCT, TOP, not empty list of expressions, list of expressions, list of elements, expression with optional alias, element of expression with optional alias, lambda expression, CAST operator, NOT, INTERVAL, CASE, DATE, TIMESTAMP, tuple, collection of literals, array, number, literal, NULL, NULL, Bool, TRUE, FALSE, string literal, asterisk, qualified asterisk, compound identifier, identifier, COLUMNS matcher, COLUMNS, qualified COLUMNS matcher, function name, substitution, MySQL-style global variable. (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:47992) (comment: 01949_heredoc_unfinished.sh) (in query: SELECT $$ ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000009fd29ed 3. /build/src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9acc 4. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 5. /build/src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba32be 6. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 7. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 8. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 9. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:03:41.528884 [ 3542 ] {45b0f870-0c23-4bfd-8a0a-61dd4b7cb218} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 8 ($): $$ . Expected one of: ALL, DISTINCT ON, DISTINCT, TOP, not empty list of expressions, list of expressions, list of elements, expression with optional alias, element of expression with optional alias, lambda expression, CAST operator, NOT, INTERVAL, CASE, DATE, TIMESTAMP, tuple, collection of literals, array, number, literal, NULL, NULL, Bool, TRUE, FALSE, string literal, asterisk, qualified asterisk, compound identifier, identifier, COLUMNS matcher, COLUMNS, qualified COLUMNS matcher, function name, substitution, MySQL-style global variable. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000009fd29ed 3. /build/src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9acc 4. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 5. /build/src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba32be 6. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 7. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 8. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 9. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:03:41.674040 [ 6532 ] {a9e06f4f-456b-45e2-9a1c-6c6d273ad8fa} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 76.39 MiB (attempt to allocate chunk of 76.39 MiB bytes), maximum: 15.26 MiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35574) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000000fb2de96 4. /build/src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2ca0a 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2c5bf 6. /build/src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000fa9410c 7. /build/src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000000fa92c7f 8. /build/src/Common/PODArray.h:152: void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::reserve_exact<>(unsigned long) @ 0x000000000a154727 9. /build/src/Interpreters/HashJoin/HashJoin.cpp:880: DB::HashJoin::joinBlockImplCross(DB::Block&, std::shared_ptr&) const @ 0x0000000014c9f34c 10. /build/src/Interpreters/HashJoin/HashJoin.cpp:1050: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000014ca133c 11. /build/src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000016b35885 12. /build/src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x0000000016d03ae4 13. /build/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) @ 0x0000000016d0186d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, 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&&) @ 0x00000000148cff60 15. /build/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&) @ 0x00000000148bfc49 16. /build/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&) @ 0x00000000148ae9e9 17. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 18. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 20. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:03:41.750396 [ 6532 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 76.39 MiB (attempt to allocate chunk of 76.39 MiB bytes), maximum: 15.26 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000000fb2de96 4. /build/src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2ca0a 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2c5bf 6. /build/src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000fa9410c 7. /build/src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000000fa92c7f 8. /build/src/Common/PODArray.h:152: void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::reserve_exact<>(unsigned long) @ 0x000000000a154727 9. /build/src/Interpreters/HashJoin/HashJoin.cpp:880: DB::HashJoin::joinBlockImplCross(DB::Block&, std::shared_ptr&) const @ 0x0000000014c9f34c 10. /build/src/Interpreters/HashJoin/HashJoin.cpp:1050: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000014ca133c 11. /build/src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000016b35885 12. /build/src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x0000000016d03ae4 13. /build/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) @ 0x0000000016d0186d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, 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&&) @ 0x00000000148cff60 15. /build/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&) @ 0x00000000148bfc49 16. /build/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&) @ 0x00000000148ae9e9 17. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 18. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 20. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:03:41.844750 [ 6608 ] {168c0a94-4e21-48d0-b206-8f40c7255368} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 8 ($): $ . Expected one of: ALL, DISTINCT ON, DISTINCT, TOP, not empty list of expressions, list of expressions, list of elements, expression with optional alias, element of expression with optional alias, lambda expression, CAST operator, NOT, INTERVAL, CASE, DATE, TIMESTAMP, tuple, collection of literals, array, number, literal, NULL, NULL, Bool, TRUE, FALSE, string literal, asterisk, qualified asterisk, compound identifier, identifier, COLUMNS matcher, COLUMNS, qualified COLUMNS matcher, function name, substitution, MySQL-style global variable. (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:48008) (comment: 01949_heredoc_unfinished.sh) (in query: SELECT $ ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000009fd29ed 3. /build/src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9acc 4. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 5. /build/src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba32be 6. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 7. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 8. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 9. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:03:41.855707 [ 6608 ] {168c0a94-4e21-48d0-b206-8f40c7255368} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 8 ($): $ . Expected one of: ALL, DISTINCT ON, DISTINCT, TOP, not empty list of expressions, list of expressions, list of elements, expression with optional alias, element of expression with optional alias, lambda expression, CAST operator, NOT, INTERVAL, CASE, DATE, TIMESTAMP, tuple, collection of literals, array, number, literal, NULL, NULL, Bool, TRUE, FALSE, string literal, asterisk, qualified asterisk, compound identifier, identifier, COLUMNS matcher, COLUMNS, qualified COLUMNS matcher, function name, substitution, MySQL-style global variable. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000009fd29ed 3. /build/src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9acc 4. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 5. /build/src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba32be 6. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 7. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 8. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 9. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:03:42.541275 [ 6619 ] {d0e02344-dbf8-41c7-8bac-15653f169b98} executeQuery: Code: 252. DB::Exception: Too many parts (1 with average size of 320.00 B) in table 'test_8zg910xt.table_for_alter (721a7370-0032-4131-ac2f-063488f54318)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34462) (comment: 00980_merge_alter_settings.sql) (query 12, line 31) (in query: INSERT INTO table_for_alter VALUES ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x00000000162b8e2b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:4936: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x000000001627234a 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 6. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f6bd 7. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 8. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 9. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 10. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:103: DB::PushingPipelineExecutor::start() @ 0x00000000168e37c5 11. /build/src/Server/TCPHandler.cpp:1112: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x0000000016810a7d 12. /build/src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x0000000016806e9c 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:03:42.556456 [ 6619 ] {} TCPHandler: Code: 252. DB::Exception: Too many parts (1 with average size of 320.00 B) in table 'test_8zg910xt.table_for_alter (721a7370-0032-4131-ac2f-063488f54318)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x00000000162b8e2b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:4936: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x000000001627234a 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 6. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f6bd 7. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 8. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 9. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 10. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:103: DB::PushingPipelineExecutor::start() @ 0x00000000168e37c5 11. /build/src/Server/TCPHandler.cpp:1112: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x0000000016810a7d 12. /build/src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x0000000016806e9c 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:03:42.692039 [ 6619 ] {f65ba3dd-e58d-48d8-a64e-81e56330a4f4} 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]:34462) (comment: 00980_merge_alter_settings.sql) (query 13, line 33) (in query: DETACH TABLE table_for_alter;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Databases/DatabaseReplicated.cpp:1106: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013cc3688 5. /build/src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc384b 6. /build/src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833287 7. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 8. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 9. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:03:42.704316 [ 6619 ] {} TCPHandler: Code: 80. DB::Exception: DETACH TABLE is not allowed for Replicated databases. Use DETACH TABLE PERMANENTLY or SYSTEM RESTART REPLICA or set database_replicated_always_detach_permanently to 1. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Databases/DatabaseReplicated.cpp:1106: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013cc3688 5. /build/src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc384b 6. /build/src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833287 7. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 8. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 9. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:03:43.633679 [ 5990 ] {7958621c-da05-41b3-bc79-a64251af2b14} executeQuery: Code: 252. DB::Exception: Too many parts (1 with average size of 305.00 B) in table 'test_73k9lyss.async_inserts (6141761a-8951-4372-92e5-d4012bc70f96)'. 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: 02015_async_inserts_5.sh) (in query: INSERT INTO test_73k9lyss.async_inserts (id, s) FORMAT JSONEachRow), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x00000000162b8e2b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:4936: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x000000001627234a 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 6. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f6bd 7. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 8. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 9. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 10. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 11. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 12. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000168cfa64 13. /build/src/Interpreters/AsynchronousInsertQueue.cpp:996: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x00000000143021bc 14. /build/src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:se190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000014305104 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 18. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:03:43.639970 [ 5990 ] {} AsynchronousInsertQueue: Failed insertion for query 'INSERT INTO test_73k9lyss.async_inserts (id, s) FORMAT JSONEachRow': Code: 252. DB::Exception: Too many parts (1 with average size of 305.00 B) in table 'test_73k9lyss.async_inserts (6141761a-8951-4372-92e5-d4012bc70f96)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x00000000162b8e2b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:4936: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x000000001627234a 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 6. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f6bd 7. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 8. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 9. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 10. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 11. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 12. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000168cfa64 13. /build/src/Interpreters/AsynchronousInsertQueue.cpp:996: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x00000000143021bc 14. /build/src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:se190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000014305104 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 18. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:03:43.639807 [ 5806 ] {e629241f-d969-42ab-995a-ef796df2f202} executeQuery: Code: 252. DB::Exception: Too many parts (1 with average size of 305.00 B) in table 'test_73k9lyss.async_inserts (6141761a-8951-4372-92e5-d4012bc70f96)'. 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: 02015_async_inserts_5.sh) (in query: INSERT INTO test_73k9lyss.async_inserts (id, s) FORMAT JSONEachRow), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x00000000162b8e2b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:4936: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x000000001627234a 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 6. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f6bd 7. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 8. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 9. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 10. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 11. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 12. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000168cfa64 13. /build/src/Interpreters/AsynchronousInsertQueue.cpp:996: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x00000000143021bc 14. /build/src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:se190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000014305104 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 18. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:03:43.654372 [ 5806 ] {} AsynchronousInsertQueue: Failed insertion for query 'INSERT INTO test_73k9lyss.async_inserts (id, s) FORMAT JSONEachRow': Code: 252. DB::Exception: Too many parts (1 with average size of 305.00 B) in table 'test_73k9lyss.async_inserts (6141761a-8951-4372-92e5-d4012bc70f96)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x00000000162b8e2b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:4936: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x000000001627234a 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 6. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f6bd 7. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 8. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 9. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 10. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 11. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 12. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000168cfa64 13. /build/src/Interpreters/AsynchronousInsertQueue.cpp:996: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x00000000143021bc 14. /build/src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:se190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000014305104 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 18. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:03:43.654458 [ 6614 ] {d53d6c22-6168-4566-a46a-9e4dd88d223d} executeQuery: Code: 252. DB::Exception: Too many parts (1 with average size of 305.00 B) in table 'test_73k9lyss.async_inserts (6141761a-8951-4372-92e5-d4012bc70f96)'. 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]:48030) (comment: 02015_async_inserts_5.sh) (in query: INSERT INTO async_inserts FORMAT JSONEachRow ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x00000000162b8e2b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:4936: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x000000001627234a 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 6. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f6bd 7. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 8. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 9. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 10. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 11. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 12. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000168cfa64 13. /build/src/Interpreters/AsynchronousInsertQueue.cpp:996: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x00000000143021bc 14. /build/src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:se190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000014305104 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 18. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:03:43.658047 [ 6611 ] {29400e5e-570e-4668-842f-4f8fc4a7c30b} executeQuery: Code: 252. DB::Exception: Too many parts (1 with average size of 305.00 B) in table 'test_73k9lyss.async_inserts (6141761a-8951-4372-92e5-d4012bc70f96)'. 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]:48044) (comment: 02015_async_inserts_5.sh) (in query: INSERT INTO async_inserts FORMAT JSONEachRow ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x00000000162b8e2b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:4936: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x000000001627234a 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 6. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f6bd 7. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 8. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 9. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 10. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 11. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 12. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000168cfa64 13. /build/src/Interpreters/AsynchronousInsertQueue.cpp:996: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x00000000143021bc 14. /build/src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:se190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000014305104 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 18. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:03:43.659104 [ 6614 ] {d53d6c22-6168-4566-a46a-9e4dd88d223d} DynamicQueryHandler: Code: 252. DB::Exception: Too many parts (1 with average size of 305.00 B) in table 'test_73k9lyss.async_inserts (6141761a-8951-4372-92e5-d4012bc70f96)'. 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x00000000162b8e2b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:4936: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x000000001627234a 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 6. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f6bd 7. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 8. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 9. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 10. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 11. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 12. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000168cfa64 13. /build/src/Interpreters/AsynchronousInsertQueue.cpp:996: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x00000000143021bc 14. /build/src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:se190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000014305104 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 18. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:03:43.663946 [ 6611 ] {29400e5e-570e-4668-842f-4f8fc4a7c30b} DynamicQueryHandler: Code: 252. DB::Exception: Too many parts (1 with average size of 305.00 B) in table 'test_73k9lyss.async_inserts (6141761a-8951-4372-92e5-d4012bc70f96)'. 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x00000000162b8e2b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:4936: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x000000001627234a 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 6. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f6bd 7. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 8. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 9. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 10. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 11. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 12. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000168cfa64 13. /build/src/Interpreters/AsynchronousInsertQueue.cpp:996: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x00000000143021bc 14. /build/src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:se190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000014305104 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 18. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:03:43.671158 [ 6608 ] {bfc0f6d0-fd6e-45ad-97dc-20acb1702a2c} executeQuery: Code: 252. DB::Exception: Too many parts (1 with average size of 305.00 B) in table 'test_73k9lyss.async_inserts (6141761a-8951-4372-92e5-d4012bc70f96)'. 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]:48018) (comment: 02015_async_inserts_5.sh) (in query: INSERT INTO async_inserts FORMAT JSONEachRow ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x00000000162b8e2b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:4936: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x000000001627234a 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 6. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f6bd 7. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 8. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 9. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 10. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 11. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 12. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000168cfa64 13. /build/src/Interpreters/AsynchronousInsertQueue.cpp:996: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x00000000143021bc 14. /build/src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:se190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000014305104 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 18. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:03:43.674734 [ 6608 ] {bfc0f6d0-fd6e-45ad-97dc-20acb1702a2c} DynamicQueryHandler: Code: 252. DB::Exception: Too many parts (1 with average size of 305.00 B) in table 'test_73k9lyss.async_inserts (6141761a-8951-4372-92e5-d4012bc70f96)'. 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x00000000162b8e2b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:4936: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x000000001627234a 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 6. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f6bd 7. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 8. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 9. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 10. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 11. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 12. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000168cfa64 13. /build/src/Interpreters/AsynchronousInsertQueue.cpp:996: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x00000000143021bc 14. /build/src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:se190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000014305104 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 18. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:03:44.983126 [ 5117 ] {21717d52-c79b-4cd6-93f2-3227d004ea36} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=8, jobs=2): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34500) (comment: 00660_optimize_final_without_partition.sql) (query 10, line 17) (in query: SELECT * FROM partitioned_by_tuple ORDER BY d, x, w, y;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x00000000163993d1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016396620 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001639641f 10. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000163ced63 11. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000163cffce 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013b9f869 13. /build/src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000013b9fb5d 14. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000163ccfc4 15. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:59: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000163ccdcc 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x00000000162f3280 17. /build/src/Storages/MergeTree/MergeTreeDataPartWide.cpp:52: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x00000000162ee6be 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x00000000163d9d66 19. /build/src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x0000000016d7885f 20. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x0000000016d9cdca 21. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5520 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 23. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 25. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 26. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 27. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 28. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 29. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 31. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 2025.07.13 02:03:45.055917 [ 5117 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=8, jobs=2): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x00000000163993d1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016396620 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001639641f 10. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000163ced63 11. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000163cffce 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013b9f869 13. /build/src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000013b9fb5d 14. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000163ccfc4 15. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:59: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000163ccdcc 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x00000000162f3280 17. /build/src/Storages/MergeTree/MergeTreeDataPartWide.cpp:52: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x00000000162ee6be 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x00000000163d9d66 19. /build/src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x0000000016d7885f 20. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x0000000016d9cdca 21. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5520 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 23. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 25. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 26. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 27. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 28. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 29. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 31. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:03:45.545878 [ 5872 ] {9db5f9ce-25ed-4c66-a19a-0c62f7e4baf4} 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]:34390) (comment: 02155_dictionary_comment.sql) (query 20, line 45) (in query: ALTER TABLE 02155_test_dictionary_view COMMENT COLUMN value 'value_column';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::AlterCommand::Type const&, String&&) @ 0x0000000013380c0b 4. /build/src/Storages/StorageDictionary.cpp:303: DB::StorageDictionary::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000015c79a5c 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd033 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:03:45.579113 [ 5872 ] {} TCPHandler: Code: 48. DB::Exception: Alter of type 'COMMENT_COLUMN' is not supported by storage Dictionary. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::AlterCommand::Type const&, String&&) @ 0x0000000013380c0b 4. /build/src/Storages/StorageDictionary.cpp:303: DB::StorageDictionary::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000015c79a5c 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd033 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:03:45.580283 [ 6614 ] {cb26787d-d72c-4ade-81f8-504cc4e09f33} 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:03:45.698355 [ 6614 ] {cb26787d-d72c-4ade-81f8-504cc4e09f33} 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]:35632) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000015f79f49 3. /build/src/Storages/getStructureOfRemoteTable.cpp:177: DB::getStructureOfRemoteTable(DB::Cluster const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x0000000015f78504 4. /build/src/TableFunctions/TableFunctionRemote.cpp:337: DB::TableFunctionRemote::getActualTableStructure(std::shared_ptr, bool) const @ 0x00000000117030ab 5. /build/src/TableFunctions/TableFunctionRemote.cpp:309: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000117028c0 6. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000130d4903 7. /build/src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000143537f2 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3da49 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:03:45.758505 [ 6614 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000015f79f49 3. /build/src/Storages/getStructureOfRemoteTable.cpp:177: DB::getStructureOfRemoteTable(DB::Cluster const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x0000000015f78504 4. /build/src/TableFunctions/TableFunctionRemote.cpp:337: DB::TableFunctionRemote::getActualTableStructure(std::shared_ptr, bool) const @ 0x00000000117030ab 5. /build/src/TableFunctions/TableFunctionRemote.cpp:309: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000117028c0 6. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000130d4903 7. /build/src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000143537f2 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3da49 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:03:45.794699 [ 6619 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000013779f8b 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000137794b8 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778bc3 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678d325 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:03:47.156530 [ 4629 ] {c9e36a60-1c16-41b1-9fd1-4698fbdcd386} 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:03:48.275574 [ 6614 ] {107d66c3-bcbb-405e-b412-b16006e2777c} 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:03:48.840518 [ 5988 ] {107d66c3-bcbb-405e-b412-b16006e2777c} 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:03:49.064475 [ 6611 ] {62b3b987-65ce-4c66-8992-3b1e3f8c210d} 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]:35698) (comment: 00599_create_view_with_subquery.sql) (query 5, line 7) (in query: DETACH TABLE test_view_00599;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Databases/DatabaseReplicated.cpp:1106: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013cc3688 5. /build/src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc384b 6. /build/src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833287 7. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 8. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 9. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:03:49.088002 [ 6611 ] {} TCPHandler: Code: 80. DB::Exception: DETACH TABLE is not allowed for Replicated databases. Use DETACH TABLE PERMANENTLY or SYSTEM RESTART REPLICA or set database_replicated_always_detach_permanently to 1. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Databases/DatabaseReplicated.cpp:1106: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013cc3688 5. /build/src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc384b 6. /build/src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833287 7. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 8. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 9. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:03:49.697065 [ 6168 ] {e96d21c6-3efc-4322-be63-78a698b7a4b7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=793, jobs=774). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35686) (comment: 00691_array_distinct.sql) (query 9, line 12) (in query: SELECT arrayDistinct(materialize([0, NULL, 0])) FROM numbers(2);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbdd1d3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd751c 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 9. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 10. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:03:49.720952 [ 6168 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=793, jobs=774). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbdd1d3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd751c 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 9. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 10. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:03:51.649734 [ 5117 ] {06e23598-a180-488f-af1f-8c5215124630} executeQuery: Code: 153. DB::Exception: Cannot perform integer division on infinite or too large floating point numbers: while executing 'FUNCTION intDiv(__table1.number :: 2, nan_Float64 :: 1) -> intDiv(__table1.number, nan_Float64) Int64 : 0'. (ILLEGAL_DIVISION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52338) (comment: 01683_intdiv_ubsan.sql) (query 1, line 1) (in query: SELECT DISTINCT intDiv(number, nan) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/DivisionUtils.h:95: long DB::DivideIntegralImpl::apply(unsigned long, double) @ 0x000000000c1fe8c1 5. /build/src/Functions/FunctionBinaryArithmetic.h:291: void DB::impl_::BinaryOperation, long>::process<(DB::impl_::OpCase)2>(unsigned long const*, double const*, long*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000c1fe6de 6. /build/src/Functions/FunctionBinaryArithmetic.h:2349: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000c40055b 7. /build/src/Functions/FunctionBinaryArithmetic.h:2508: auto auto bool DB::FunctionBinaryArithmetic::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)::operator()>(auto const&) const @ 0x000000000c3f6787 8. /build/src/Functions/castTypeToEither.h:18: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000c3f6218 9. /build/src/Functions/FunctionBinaryArithmetic.h:846: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000c3d3203 10. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000c3cf585 11. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c3cdb0c 12. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c3cc994 13. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 14. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 17. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 18. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 19. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 20. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 21. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 22. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 23. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 24. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 25. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 26. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 28. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:03:51.663729 [ 5117 ] {} TCPHandler: Code: 153. DB::Exception: Cannot perform integer division on infinite or too large floating point numbers: while executing 'FUNCTION intDiv(__table1.number :: 2, nan_Float64 :: 1) -> intDiv(__table1.number, nan_Float64) Int64 : 0'. (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/DivisionUtils.h:95: long DB::DivideIntegralImpl::apply(unsigned long, double) @ 0x000000000c1fe8c1 5. /build/src/Functions/FunctionBinaryArithmetic.h:291: void DB::impl_::BinaryOperation, long>::process<(DB::impl_::OpCase)2>(unsigned long const*, double const*, long*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000c1fe6de 6. /build/src/Functions/FunctionBinaryArithmetic.h:2349: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000c40055b 7. /build/src/Functions/FunctionBinaryArithmetic.h:2508: auto auto bool DB::FunctionBinaryArithmetic::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)::operator()>(auto const&) const @ 0x000000000c3f6787 8. /build/src/Functions/castTypeToEither.h:18: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000c3f6218 9. /build/src/Functions/FunctionBinaryArithmetic.h:846: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000c3d3203 10. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000c3cf585 11. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c3cdb0c 12. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c3cc994 13. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 14. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 17. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 18. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 19. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 20. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 21. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 22. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 23. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 24. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 25. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 26. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 28. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:03:53.062185 [ 6608 ] {b2efcf38-4a87-46af-8c50-632e8ce7c821} executeQuery: Code: 47. DB::Exception: Qualified matcher statement1.* does not find table. In scope WITH statement1 AS (SELECT '' AS name FROM test_table), statement2 AS (SELECT '' AS name FROM test_table) SELECT statement1.*, statement2.*. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52380) (comment: 03356_analyzer_qualified_matcher_error.sql) (query 2, line 8) (in query: WITH statement1 AS ( SELECT '' AS name FROM test_table ), statement2 AS ( SELECT '' AS name FROM test_table ) SELECT statement1.*, statement2.*;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1882: DB::QueryAnalyzer::resolveQualifiedMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4cdd1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2204: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5a3b1 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3800: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38d68 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 11. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 12. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 17. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 19. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 20. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 2025.07.13 02:03:53.069858 [ 6608 ] {} TCPHandler: Code: 47. DB::Exception: Qualified matcher statement1.* does not find table. In scope WITH statement1 AS (SELECT '' AS name FROM test_table), statement2 AS (SELECT '' AS name FROM test_table) SELECT statement1.*, statement2.*. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1882: DB::QueryAnalyzer::resolveQualifiedMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4cdd1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2204: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5a3b1 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3800: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38d68 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 11. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 12. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 17. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 19. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 20. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 2025.07.13 02:03:53.164132 [ 6608 ] {58570c0a-ad57-4979-954d-c65474547c2b} executeQuery: Code: 47. DB::Exception: Qualified matcher t.* does not find table. In scope WITH t AS (SELECT sum(number) AS x FROM numbers(10)) SELECT t.*. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52380) (comment: 03356_analyzer_qualified_matcher_error.sql) (query 3, line 23) (in query: WITH t as (SELECT sum(number) as x FROM numbers(10)) SELECT t.*;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1882: DB::QueryAnalyzer::resolveQualifiedMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4cdd1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2204: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5a3b1 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3800: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38d68 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 11. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 12. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 17. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 19. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 20. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 2025.07.13 02:03:53.172622 [ 6608 ] {} TCPHandler: Code: 47. DB::Exception: Qualified matcher t.* does not find table. In scope WITH t AS (SELECT sum(number) AS x FROM numbers(10)) SELECT t.*. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1882: DB::QueryAnalyzer::resolveQualifiedMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4cdd1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2204: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5a3b1 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3800: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38d68 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 11. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 12. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 17. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 19. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 20. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 2025.07.13 02:03:53.295699 [ 6608 ] {387f3b02-cb25-4f2b-9b29-bdc4c8c164ad} executeQuery: Code: 47. DB::Exception: Qualified matcher a.* does not find table. In scope WITH a AS (SELECT 1) SELECT a.* FROM (SELECT 1 FROM a). (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52380) (comment: 03356_analyzer_qualified_matcher_error.sql) (query 4, line 27) (in query: WITH a AS (SELECT 1) SELECT a.* FROM (SELECT 1 FROM a);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1882: DB::QueryAnalyzer::resolveQualifiedMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4cdd1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2204: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5a3b1 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3800: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38d68 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 11. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 12. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 17. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 19. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 20. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 2025.07.13 02:03:53.317884 [ 6608 ] {} TCPHandler: Code: 47. DB::Exception: Qualified matcher a.* does not find table. In scope WITH a AS (SELECT 1) SELECT a.* FROM (SELECT 1 FROM a). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1882: DB::QueryAnalyzer::resolveQualifiedMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4cdd1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2204: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5a3b1 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3800: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38d68 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 11. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 12. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 17. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 19. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 20. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 2025.07.13 02:03:53.726629 [ 6608 ] {b48be270-fd50-4b15-ba7d-5e05b5b1655a} executeQuery: Code: 47. DB::Exception: Qualified matcher t.* does not find table. In scope t1 AS (SELECT t.* FROM numbers(1)). (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52380) (comment: 03356_analyzer_qualified_matcher_error.sql) (query 5, line 29) (in query: WITH t as (SELECT sum(number) as x FROM numbers(10)), t1 as (SELECT t.* FROM numbers(1)) SELECT * FROM t1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1882: DB::QueryAnalyzer::resolveQualifiedMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4cdd1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2204: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5a3b1 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3800: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38d68 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38a1e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f64224 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:03:53.774401 [ 6608 ] {} TCPHandler: Code: 47. DB::Exception: Qualified matcher t.* does not find table. In scope t1 AS (SELECT t.* FROM numbers(1)). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1882: DB::QueryAnalyzer::resolveQualifiedMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4cdd1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2204: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5a3b1 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3800: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38d68 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38a1e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f64224 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:03:54.020112 [ 4870 ] {6ea1e22f-c093-4857-9320-8c44d86838b4} 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]:45710) (comment: 03356_analyzer_qualified_matcher_error.sql) (in query: DROP DATABASE IF EXISTS test_nr22yeob SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:03:54.026647 [ 4870 ] {6ea1e22f-c093-4857-9320-8c44d86838b4} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:03:54.366760 [ 4281 ] {da5eab3b-357c-4343-835f-5a2fb46bbda1::202507_1_21_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=8, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x00000000163993d1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016396620 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001639641f 10. /build/src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000163b2bd7 11. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x00000000162ea22d 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x00000000162e6974 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x00000000163d9d66 14. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:159: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::Block, DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr, std::shared_ptr, std::optional, bool, bool) @ 0x00000000163d3337 15. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:se190107] const&, std::shared_ptr, std::optional, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x00000000163d9212 16. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x00000000163d553a 17. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:383: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000163d7ceb 18. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016cf6870 19. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 20. /build/src/Storages/MergeTree/MergeTask.cpp:1910: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() const @ 0x00000000161f8487 21. /build/src/Storages/MergeTree/MergeTask.cpp:567: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000161f2613 22. /build/src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000161f9939 23. /build/src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000161ffd8a 24. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000016592b05 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 26. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 28. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 30. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 31. ? @ 0x00007f7210eb6ac3 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:03:54.429977 [ 4281 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {da5eab3b-357c-4343-835f-5a2fb46bbda1::202507_1_21_4}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=8, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x00000000163993d1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016396620 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001639641f 10. /build/src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000163b2bd7 11. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x00000000162ea22d 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x00000000162e6974 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x00000000163d9d66 14. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:159: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::Block, DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr, std::shared_ptr, std::optional, bool, bool) @ 0x00000000163d3337 15. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:se190107] const&, std::shared_ptr, std::optional, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x00000000163d9212 16. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x00000000163d553a 17. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:383: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000163d7ceb 18. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016cf6870 19. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 20. /build/src/Storages/MergeTree/MergeTask.cpp:1910: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() const @ 0x00000000161f8487 21. /build/src/Storages/MergeTree/MergeTask.cpp:567: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000161f2613 22. /build/src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000161f9939 23. /build/src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000161ffd8a 24. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000016592b05 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 26. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 28. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 30. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 31. ? @ 0x00007f7210eb6ac3 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:03:56.065760 [ 3542 ] {} TCPHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000013779f8b 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000137794b8 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778c58 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168167bf 10. /build/src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000001680ff45 11. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:03:56.068680 [ 3542 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x0000000016810069 5. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 6. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 2025.07.13 02:03:56.109004 [ 6619 ] {234861f1-e6bc-4589-89b1-9689cb8e332b} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000013779f8b 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000137794b8 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778c58 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168167bf 10. /build/src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000001680ff45 11. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52460) (comment: 01932_null_valid_identifier.sql) (query 1, line 1) (in query: SELECT `null` FROM remote('127.0.0.2', view(SELECT 1 AS `null`));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fb80677 3. /build/src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x00000000166f5247 4. /build/src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000166fc432 5. /build/src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001673a5f3 6. /build/src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013af6952 7. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013af679a 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013af64e1 2025.07.13 02:03:56.139026 [ 6619 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000013779f8b 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000137794b8 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778c58 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168167bf 10. /build/src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000001680ff45 11. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fb80677 3. /build/src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x00000000166f5247 4. /build/src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000166fc432 5. /build/src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001673a5f3 6. /build/src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013af6952 7. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013af679a 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013af64e1 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:03:56.808246 [ 6619 ] {95998e59-049d-42d2-9b8f-883be0285d99} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=802, jobs=783). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52502) (comment: 00944_clear_index_in_partition.sh) (query 1, line 1) (in query: SELECT count() FROM minmax_idx WHERE i64 = 2 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbdd1d3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd751c 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 9. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 10. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:03:56.831919 [ 5998 ] {acd50d2b-a327-4a0f-93fe-b9dcb29d7f9c} executeQuery: Code: 207. DB::Exception: JOIN , ... ambiguous identifier 'id'. In scope SELECT id FROM test_table_join_1, test_table_join_2. (AMBIGUOUS_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34506) (comment: 02371_analyzer_join_cross.sql) (query 33, line 73) (in query: SELECT id FROM test_table_join_1, test_table_join_2;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000013f6a64b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:821: DB::IdentifierResolver::tryResolveIdentifierFromCrossJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141dda5c 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1331: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141ddd3c 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000141e1431 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000013f4860b 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f392f4 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:03:56.839854 [ 6619 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=802, jobs=783). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbdd1d3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd751c 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 9. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 10. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:03:56.847880 [ 5998 ] {} TCPHandler: Code: 207. DB::Exception: JOIN , ... ambiguous identifier 'id'. In scope SELECT id FROM test_table_join_1, test_table_join_2. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000013f6a64b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:821: DB::IdentifierResolver::tryResolveIdentifierFromCrossJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141dda5c 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1331: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141ddd3c 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000141e1431 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000013f4860b 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f392f4 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:03:57.050547 [ 5998 ] {15d74f74-22af-4d03-8a10-54c6156efc92} executeQuery: Code: 207. DB::Exception: JOIN , ... ambiguous identifier 'value'. In scope SELECT value FROM test_table_join_1, test_table_join_2. (AMBIGUOUS_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34506) (comment: 02371_analyzer_join_cross.sql) (query 34, line 75) (in query: SELECT value FROM test_table_join_1, test_table_join_2;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000013f6a64b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:821: DB::IdentifierResolver::tryResolveIdentifierFromCrossJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141dda5c 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1331: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141ddd3c 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000141e1431 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000013f4860b 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f392f4 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:03:57.102036 [ 5998 ] {} TCPHandler: Code: 207. DB::Exception: JOIN , ... ambiguous identifier 'value'. In scope SELECT value FROM test_table_join_1, test_table_join_2. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000013f6a64b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:821: DB::IdentifierResolver::tryResolveIdentifierFromCrossJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141dda5c 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1331: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141ddd3c 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000141e1431 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000013f4860b 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f392f4 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:03:57.105557 [ 6168 ] {b9d8b57e-622f-4c0a-b7fb-2413b141ed0b} StorageBuffer (test_fr94h8vw.realtimebuff__fuzz_19): Destination table test_fr94h8vw.realtimedistributed has different type of column amount (Int32 != UInt32). Data from destination table are converted. 2025.07.13 02:03:57.991413 [ 6614 ] {b7080c35-3d24-4a04-bc70-fe7721c1f886} executeQuery: Code: 471. DB::Exception: Invalid type Bool for setting "header" only integer settings are supported. (INVALID_SETTING_VALUE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52304) (comment: 02271_fix_column_matcher_and_column_transformer.sql) (query 7, line 75) (in query: EXPLAIN PIPELINE header = true, compact = true WITH top_repos AS (SELECT repo_name FROM github_events__fuzz_0 WHERE (event_type = 'WatchEvent') AND (toDate(created_at) = (today() - 1)) GROUP BY repo_name ORDER BY count() DESC LIMIT 100 UNION DISTINCT SELECT repo_name FROM github_events__fuzz_0 WHERE (event_type = 'WatchEvent') AND (toMonday(created_at) = toMonday(today() - toIntervalWeek(1))) GROUP BY repo_name ORDER BY count() DESC LIMIT 100 UNION DISTINCT SELECT repo_name FROM github_events__fuzz_0 PREWHERE (event_type = 'WatchEvent') AND (toStartOfMonth(created_at) = (toStartOfMonth(today()) - toIntervalMonth(1))) GROUP BY repo_name ORDER BY count() DESC LIMIT 100 UNION DISTINCT SELECT repo_name FROM github_events WHERE (event_type = 'WatchEvent') AND (toYear(created_at) = (toYear(today()) - 1)) GROUP BY repo_name ORDER BY count() DESC LIMIT 100), last_day AS (SELECT repo_name, count() AS count_last_day, rowNumberInAllBlocks() + 1 AS position_last_day FROM github_events WHERE (repo_name IN (SELECT repo_name FROM top_repos)) AND (toDate(created_at) = (today() - 1)) GROUP BY repo_name ORDER BY count_last_day DESC), last_week AS (SELECT repo_name, count() AS count_last_week, rowNumberInAllBlocks() + 1 AS position_last_week FROM github_events WHERE (repo_name IN (SELECT repo_name FROM top_repos)) AND (toMonday(created_at) = (toMonday(today()) - toIntervalWeek(2))) GROUP BY repo_name ORDER BY count_last_week DESC), last_month AS (SELECT repo_name, count() AS count_last_month, rowNumberInAllBlocks() + 1 AS position_last_month FROM github_events__fuzz_0 WHERE ('deleted' = 4) AND in(repo_name) AND (toStartOfMonth(created_at) = (toStartOfMonth(today()) - toIntervalMonth(1))) GROUP BY repo_name ORDER BY count_last_month DESC) SELECT d.repo_name, COLUMNS(count) FROM last_day AS d INNER JOIN last_week AS w ON d.repo_name = w.repo_name INNER JOIN last_month AS m ON d.repo_name = m.repo_name format Null;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>, String const&>(int, FormatStringHelperImpl>>::type, std::type_identity::type>, std::basic_string_view>&&, String const&) @ 0x000000001335534b 4. /build/src/Interpreters/InterpreterExplainQuery.cpp:367: DB::InterpreterExplainQuery::executeImpl() @ 0x000000001483b9e0 5. /build/src/Interpreters/InterpreterExplainQuery.cpp:130: DB::InterpreterExplainQuery::execute() @ 0x0000000014838307 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:03:58.026200 [ 6614 ] {} TCPHandler: Code: 471. DB::Exception: Invalid type Bool for setting "header" only integer settings are supported. (INVALID_SETTING_VALUE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>, String const&>(int, FormatStringHelperImpl>>::type, std::type_identity::type>, std::basic_string_view>&&, String const&) @ 0x000000001335534b 4. /build/src/Interpreters/InterpreterExplainQuery.cpp:367: DB::InterpreterExplainQuery::executeImpl() @ 0x000000001483b9e0 5. /build/src/Interpreters/InterpreterExplainQuery.cpp:130: DB::InterpreterExplainQuery::execute() @ 0x0000000014838307 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:03:58.056794 [ 4126 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000118cbf6e 8. /build/src/Storages/StorageBuffer.cpp:920: DB::StorageBuffer::flushAllBuffers(bool) @ 0x0000000015f9bd56 9. /build/src/Storages/StorageBuffer.cpp:1094: DB::StorageBuffer::backgroundFlush() @ 0x0000000015f9f5b2 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013882414 11. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000138854aa 12. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000013885c47 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 14. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:03:58.429363 [ 6168 ] {4440ba74-29b4-49e4-b401-8514342f64b9} StorageBuffer (test_fr94h8vw.realtimebuff__fuzz_19): Destination table test_fr94h8vw.realtimedistributed has different type of column amount (Int32 != UInt32). Data from destination table are converted. 2025.07.13 02:03:59.403227 [ 6168 ] {ece48822-f197-4f8f-8964-516b54b8d51d} StorageBuffer (test_fr94h8vw.realtimebuff__fuzz_20): Destination table test_fr94h8vw.realtimedistributed has different type of column amount (Int32 != Nullable(Int32)). Data from destination table are converted. 2025.07.13 02:04:02.143420 [ 3796 ] {} DNSResolver: Cannot resolve host (localhos), error 0: Host not found. 2025.07.13 02:04:02.195271 [ 6168 ] {af488471-edc8-42d4-8f6e-5b6e647bbe54} StorageBuffer (test_fr94h8vw.realtimebuff__fuzz_19): Destination table test_fr94h8vw.realtimedistributed has different type of column amount (Int32 != UInt32). Data from destination table are converted. 2025.07.13 02:04:02.528283 [ 6608 ] {8afd31cb-4668-4126-a13a-8658fa6cbea1} executeQuery: Code: 69. DB::Exception: A call to function range would produce 18446744073709550590 array elements, which is greater than the allowed maximum of 500000000: In scope SELECT range(1025, 18446744073709551615, 1). (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43194) (comment: 01408_range_overflow.sql) (query 3, line 4) (in query: SELECT range(1025, 18446744073709551615, 1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/array/range.cpp:366: COW::immutable_ptr DB::FunctionRange::executeGeneric(DB::IColumn const*, DB::IColumn const*, DB::IColumn const*, unsigned long) const @ 0x000000000fa6b15c 5. /build/src/Functions/array/range.cpp:553: DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fa590ed 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:04:02.575305 [ 6608 ] {} TCPHandler: Code: 69. DB::Exception: A call to function range would produce 18446744073709550590 array elements, which is greater than the allowed maximum of 500000000: In scope SELECT range(1025, 18446744073709551615, 1). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/array/range.cpp:366: COW::immutable_ptr DB::FunctionRange::executeGeneric(DB::IColumn const*, DB::IColumn const*, DB::IColumn const*, unsigned long) const @ 0x000000000fa6b15c 5. /build/src/Functions/array/range.cpp:553: DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fa590ed 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:04:03.059243 [ 6637 ] {faa76e6e-16ba-4c29-81ac-c0d2724d1574} 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]:43210) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:04:03.117590 [ 6637 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:04:03.302340 [ 6168 ] {af488471-edc8-42d4-8f6e-5b6e647bbe54} executeQuery: Code: 70. DB::Exception: Conversion from AggregateFunction(sum, Int32) to AggregateFunction(sum, UInt32) is not supported: While executing Remote. (CANNOT_CONVERT_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52368) (comment: 03208_buffer_over_distributed_type_mismatch.sql) (query 15, line 20) (in query: SELECT sum(amount) = 100 FROM realtimebuff__fuzz_19 ORDER BY ALL;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/FunctionsConversion.h:3856: DB::detail::FunctionCast::createAggregateFunctionWrapper(std::shared_ptr const&, DB::DataTypeAggregateFunction const*) const @ 0x0000000012cdb904 5. /build/src/Functions/FunctionsConversion.h:6108: DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000012cd8cff 6. /build/src/Functions/FunctionsConversion.h:5819: DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000012cc817b 7. /build/src/Functions/FunctionsConversion.h:5746: DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000012cc6f09 8. /build/src/Functions/FunctionsConversion.h:3444: DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x0000000012cc67f0 9. /build/src/Functions/IFunction.cpp:513: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c80978 10. /build/src/Interpreters/castColumn.cpp:39: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x0000000014b7474a 11. /build/src/Interpreters/castColumn.cpp:44: DB::castColumn(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x0000000014b74074 12. /build/src/QueryPipeline/RemoteQueryExecutor.cpp:356: DB::adaptBlockStructure(DB::Block const&, DB::Block const&) @ 0x0000000013adfc30 13. /build/src/QueryPipeline/RemoteQueryExecutor.cpp:658: DB::RemoteQueryExecutor::processPacket(DB::Packet) @ 0x0000000013add2a0 14. /build/src/QueryPipeline/RemoteQueryExecutor.cpp:586: DB::RemoteQueryExecutor::readAsync() @ 0x0000000013adeeca 15. /build/src/Processors/Sources/RemoteSource.cpp:182: DB::RemoteSource::tryGenerate() @ 0x0000000016c05f2c 16. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 17. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 18. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 19. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 20. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 2025.07.13 02:04:03.411669 [ 6166 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:48116, local: [::ffff:127.0.0.2]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fc62e75 3. /build/src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000fc623ee 4. /build/src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000fc62923 5. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 6. /build/src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000001680643e 7. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 12. ? @ 0x00007f7210eb6ac3 13. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:04:03.411703 [ 6615 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:54600, local: [::ffff:127.0.0.1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fc62e75 3. /build/src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000fc623ee 4. /build/src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000fc62923 5. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 6. /build/src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000001680643e 7. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 12. ? @ 0x00007f7210eb6ac3 13. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:04:03.413008 [ 6166 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:48116, local: [::ffff:127.0.0.2]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fc62e75 3. /build/src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000fc623ee 4. /build/src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000fc62923 5. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 6. /build/src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000001680643e 7. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 12. ? @ 0x00007f7210eb6ac3 13. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:04:03.414539 [ 6615 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:54600, local: [::ffff:127.0.0.1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fc62e75 3. /build/src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000fc623ee 4. /build/src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000fc62923 5. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 6. /build/src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000001680643e 7. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 12. ? @ 0x00007f7210eb6ac3 13. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:04:03.498687 [ 6168 ] {} TCPHandler: Code: 70. DB::Exception: Conversion from AggregateFunction(sum, Int32) to AggregateFunction(sum, UInt32) is not supported: While executing Remote. (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/FunctionsConversion.h:3856: DB::detail::FunctionCast::createAggregateFunctionWrapper(std::shared_ptr const&, DB::DataTypeAggregateFunction const*) const @ 0x0000000012cdb904 5. /build/src/Functions/FunctionsConversion.h:6108: DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000012cd8cff 6. /build/src/Functions/FunctionsConversion.h:5819: DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000012cc817b 7. /build/src/Functions/FunctionsConversion.h:5746: DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000012cc6f09 8. /build/src/Functions/FunctionsConversion.h:3444: DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x0000000012cc67f0 9. /build/src/Functions/IFunction.cpp:513: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c80978 10. /build/src/Interpreters/castColumn.cpp:39: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x0000000014b7474a 11. /build/src/Interpreters/castColumn.cpp:44: DB::castColumn(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x0000000014b74074 12. /build/src/QueryPipeline/RemoteQueryExecutor.cpp:356: DB::adaptBlockStructure(DB::Block const&, DB::Block const&) @ 0x0000000013adfc30 13. /build/src/QueryPipeline/RemoteQueryExecutor.cpp:658: DB::RemoteQueryExecutor::processPacket(DB::Packet) @ 0x0000000013add2a0 14. /build/src/QueryPipeline/RemoteQueryExecutor.cpp:586: DB::RemoteQueryExecutor::readAsync() @ 0x0000000013adeeca 15. /build/src/Processors/Sources/RemoteSource.cpp:182: DB::RemoteSource::tryGenerate() @ 0x0000000016c05f2c 16. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 17. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 18. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 19. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 20. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:04:03.669564 [ 6168 ] {1f7b47cb-b86c-46b8-803a-23c29982921f} StorageBuffer (test_fr94h8vw.realtimebuff__fuzz_20): Destination table test_fr94h8vw.realtimedistributed has different type of column amount (Int32 != Nullable(Int32)). Data from destination table are converted. 2025.07.13 02:04:08.718806 [ 6168 ] {1f7b47cb-b86c-46b8-803a-23c29982921f} executeQuery: Code: 70. DB::Exception: Conversion from AggregateFunction(sum, Int32) to AggregateFunction(sum, Nullable(Int32)) is not supported: While executing Remote. (CANNOT_CONVERT_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52368) (comment: 03208_buffer_over_distributed_type_mismatch.sql) (query 16, line 21) (in query: SELECT sum(amount) = 100 FROM realtimebuff__fuzz_20 ORDER BY ALL;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/FunctionsConversion.h:3856: DB::detail::FunctionCast::createAggregateFunctionWrapper(std::shared_ptr const&, DB::DataTypeAggregateFunction const*) const @ 0x0000000012cdb904 5. /build/src/Functions/FunctionsConversion.h:6108: DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000012cd8cff 6. /build/src/Functions/FunctionsConversion.h:5819: DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000012cc817b 7. /build/src/Functions/FunctionsConversion.h:5746: DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000012cc6f09 8. /build/src/Functions/FunctionsConversion.h:3444: DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x0000000012cc67f0 9. /build/src/Functions/IFunction.cpp:513: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c80978 10. /build/src/Interpreters/castColumn.cpp:39: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x0000000014b7474a 11. /build/src/Interpreters/castColumn.cpp:44: DB::castColumn(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x0000000014b74074 12. /build/src/QueryPipeline/RemoteQueryExecutor.cpp:356: DB::adaptBlockStructure(DB::Block const&, DB::Block const&) @ 0x0000000013adfc30 13. /build/src/QueryPipeline/RemoteQueryExecutor.cpp:658: DB::RemoteQueryExecutor::processPacket(DB::Packet) @ 0x0000000013add2a0 14. /build/src/QueryPipeline/RemoteQueryExecutor.cpp:586: DB::RemoteQueryExecutor::readAsync() @ 0x0000000013adeeca 15. /build/src/Processors/Sources/RemoteSource.cpp:182: DB::RemoteSource::tryGenerate() @ 0x0000000016c05f2c 16. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 17. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 18. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 19. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 20. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 2025.07.13 02:04:08.748509 [ 5872 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:44080, local: [::ffff:127.0.0.2]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fc62e75 3. /build/src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000fc623ee 4. /build/src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000fc62923 5. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 6. /build/src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000001680643e 7. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 12. ? @ 0x00007f7210eb6ac3 13. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:04:08.750529 [ 5872 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:44080, local: [::ffff:127.0.0.2]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fc62e75 3. /build/src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000fc623ee 4. /build/src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000fc62923 5. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 6. /build/src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000001680643e 7. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 12. ? @ 0x00007f7210eb6ac3 13. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:04:08.765647 [ 6608 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:58426, local: [::ffff:127.0.0.1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fc62e75 3. /build/src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000fc623ee 4. /build/src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000fc62923 5. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 6. /build/src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000001680643e 7. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 12. ? @ 0x00007f7210eb6ac3 13. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:04:08.767620 [ 6608 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:58426, local: [::ffff:127.0.0.1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fc62e75 3. /build/src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000fc623ee 4. /build/src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000fc62923 5. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 6. /build/src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000001680643e 7. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 12. ? @ 0x00007f7210eb6ac3 13. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:04:08.818031 [ 6168 ] {} TCPHandler: Code: 70. DB::Exception: Conversion from AggregateFunction(sum, Int32) to AggregateFunction(sum, Nullable(Int32)) is not supported: While executing Remote. (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/FunctionsConversion.h:3856: DB::detail::FunctionCast::createAggregateFunctionWrapper(std::shared_ptr const&, DB::DataTypeAggregateFunction const*) const @ 0x0000000012cdb904 5. /build/src/Functions/FunctionsConversion.h:6108: DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000012cd8cff 6. /build/src/Functions/FunctionsConversion.h:5819: DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000012cc817b 7. /build/src/Functions/FunctionsConversion.h:5746: DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000012cc6f09 8. /build/src/Functions/FunctionsConversion.h:3444: DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x0000000012cc67f0 9. /build/src/Functions/IFunction.cpp:513: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c80978 10. /build/src/Interpreters/castColumn.cpp:39: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x0000000014b7474a 11. /build/src/Interpreters/castColumn.cpp:44: DB::castColumn(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x0000000014b74074 12. /build/src/QueryPipeline/RemoteQueryExecutor.cpp:356: DB::adaptBlockStructure(DB::Block const&, DB::Block const&) @ 0x0000000013adfc30 13. /build/src/QueryPipeline/RemoteQueryExecutor.cpp:658: DB::RemoteQueryExecutor::processPacket(DB::Packet) @ 0x0000000013add2a0 14. /build/src/QueryPipeline/RemoteQueryExecutor.cpp:586: DB::RemoteQueryExecutor::readAsync() @ 0x0000000013adeeca 15. /build/src/Processors/Sources/RemoteSource.cpp:182: DB::RemoteSource::tryGenerate() @ 0x0000000016c05f2c 16. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 17. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 18. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 19. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 20. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:04:08.846629 [ 6168 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778c58 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168167bf 10. /build/src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000001680ff45 11. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:04:08.849399 [ 6168 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x0000000016810069 5. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 6. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 2025.07.13 02:04:09.083280 [ 5988 ] {197f76f4-d9eb-479a-8c0e-456b37180bdc} StorageBuffer (test_fr94h8vw.realtimebuff__fuzz_19): Destination table test_fr94h8vw.realtimedistributed have different type of column amount (Int32 != UInt32). Block of data is converted. 2025.07.13 02:04:09.130978 [ 11007 ] {197f76f4-d9eb-479a-8c0e-456b37180bdc} StorageBuffer (test_fr94h8vw.realtimebuff__fuzz_20): Destination table test_fr94h8vw.realtimedistributed have different type of column amount (Int32 != Nullable(Int32)). Block of data is converted. 2025.07.13 02:04:09.535653 [ 5018 ] {197f76f4-d9eb-479a-8c0e-456b37180bdc} virtual void DB::StorageBuffer::flushAndPrepareForShutdown(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000118cbf6e 8. /build/src/Storages/StorageBuffer.cpp:920: DB::StorageBuffer::flushAllBuffers(bool) @ 0x0000000015f9bd56 9. /build/src/Storages/StorageBuffer.cpp:836: DB::StorageBuffer::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x0000000015f9ba8d 10. /build/src/Storages/StorageBuffer.cpp:795: DB::StorageBuffer::flushAndPrepareForShutdown() @ 0x0000000015f9b851 11. /build/src/Storages/IStorage.h:565: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000148334eb 12. /build/src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835a47 13. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 14. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 15. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 17. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 18. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 19. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 20. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:04:15.432558 [ 6612 ] {a2a00d2c-a8a5-4839-b5bc-0f348f43c8e6} executeQuery: Code: 420. DB::Exception: Refused to materialize column `b` because it's in the sort key. Doing so could break the sort order. (CANNOT_UPDATE_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34674) (comment: 03263_forbid_materialize_sort_key.sql) (query 5, line 7) (in query: ALTER TABLE test MATERIALIZE COLUMN b;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Interpreters/MutationsInterpreter.cpp:803: DB::MutationsInterpreter::prepare(bool) @ 0x000000001494a5e3 5. /build/src/Interpreters/MutationsInterpreter.cpp:405: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x000000001494343c 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:235: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd34e 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 10. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:04:15.452237 [ 6612 ] {} TCPHandler: Code: 420. DB::Exception: Refused to materialize column `b` because it's in the sort key. Doing so could break the sort order. (CANNOT_UPDATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Interpreters/MutationsInterpreter.cpp:803: DB::MutationsInterpreter::prepare(bool) @ 0x000000001494a5e3 5. /build/src/Interpreters/MutationsInterpreter.cpp:405: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x000000001494343c 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:235: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd34e 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 10. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:04:16.005929 [ 6168 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000013779f8b 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000137794b8 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778bc3 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678d325 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:04:21.472097 [ 6612 ] {84a3d509-fbf6-4a03-9c3d-f836a25fc13d} executeQuery: Code: 420. DB::Exception: Refused to materialize column `y` because it's in the sort key. Doing so could break the sort order. (CANNOT_UPDATE_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34674) (comment: 03263_forbid_materialize_sort_key.sql) (query 17, line 21) (in query: ALTER TABLE tab2 materialize column y;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Interpreters/MutationsInterpreter.cpp:803: DB::MutationsInterpreter::prepare(bool) @ 0x000000001494a5e3 5. /build/src/Interpreters/MutationsInterpreter.cpp:405: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x000000001494343c 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:235: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd34e 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 10. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:04:21.485291 [ 6612 ] {} TCPHandler: Code: 420. DB::Exception: Refused to materialize column `y` because it's in the sort key. Doing so could break the sort order. (CANNOT_UPDATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Interpreters/MutationsInterpreter.cpp:803: DB::MutationsInterpreter::prepare(bool) @ 0x000000001494a5e3 5. /build/src/Interpreters/MutationsInterpreter.cpp:405: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x000000001494343c 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:235: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd34e 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 10. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:04:23.586249 [ 5121 ] {8c24d56f-4b59-4781-95da-9c7abeac0271} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=5): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35656) (comment: 02493_max_streams_for_merge_tree_reading.sql) (query 11, line 22) (in query: -- With asynchronous_read, read in max_streams_for_merge_tree_reading async streams and resize to max_threads select sum(x) from t settings max_threads=4, max_streams_for_merge_tree_reading=16, allow_asynchronous_read_from_io_pool_for_merge_tree=1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x0000000013397daa 8. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:se190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x0000000013397bcf 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016d68ca0 10. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 11. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 12. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 13. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 14. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 18. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:04:23.925196 [ 5121 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=5): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x0000000013397daa 8. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:se190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x0000000013397bcf 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016d68ca0 10. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 11. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 12. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 13. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 14. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 18. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:04:24.355125 [ 4267 ] {34f1c6e9-881f-45b9-bb45-752223d4bf4b::all_1_6_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 236. DB::Exception: Cancelled merging parts: While executing MergeTreeSequentialSource. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x00000000161ee9da 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016212993 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013ad6ce9 7. /build/src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd72f 8. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 9. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000168e1018 12. /build/src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000161fb0e2 13. /build/src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000161f9939 14. /build/src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000161ffd8a 15. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000016592b05 16. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 17. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 22. ? @ 0x00007f7210eb6ac3 23. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:04:25.182450 [ 4038 ] {} DNSResolver: Cannot resolve host (localhos), error 0: Host not found. 2025.07.13 02:04:26.050869 [ 6166 ] {3ff6b465-3acf-4416-b8c5-8b594706f19f} executeQuery: Code: 36. DB::Exception: Engine Distributed doesn't support TTL clause. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36308) (comment: 02184_storage_add_support_ttl.sql) (query 8, line 9) (in query: ALTER TABLE distributed_02184 MODIFY COLUMN name String TTL dt + INTERVAL 1 MONTH;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/AlterCommands.cpp:1427: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015c148a1 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fcff4 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:04:26.070459 [ 6166 ] {} TCPHandler: Code: 36. DB::Exception: Engine Distributed doesn't support TTL clause. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/AlterCommands.cpp:1427: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015c148a1 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fcff4 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:04:26.290483 [ 6637 ] {3cb9276e-a3ae-45fe-97af-90c96c4f7580} executeQuery: Code: 277. DB::Exception: Primary key (id, date) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36256) (comment: 00808_not_optimize_predicate.sql) (query 15, line 21) (in query: SELECT * FROM (SELECT * FROM test_00808 LIMIT 1) WHERE id = 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/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>&&) @ 0x0000000015ce57cb 4. /build/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) @ 0x0000000016d4fa3f 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x0000000016d4f5b9 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x0000000016d4f3b2 7. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d571cc 8. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016cf6870 9. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 14. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 15. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 20. ? @ 0x00007f7210eb6ac3 21. ? @ 0x00007f7210f48850 2025.07.13 02:04:26.322199 [ 6637 ] {} TCPHandler: Code: 277. DB::Exception: Primary key (id, date) 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/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>&&) @ 0x0000000015ce57cb 4. /build/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) @ 0x0000000016d4fa3f 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x0000000016d4f5b9 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x0000000016d4f3b2 7. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d571cc 8. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016cf6870 9. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 14. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 15. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 20. ? @ 0x00007f7210eb6ac3 21. ? @ 0x00007f7210f48850 2025.07.13 02:04:26.583307 [ 6637 ] {30e6c85a-188c-4c21-b90b-0feb209c206e} executeQuery: Code: 277. DB::Exception: Primary key (id, date) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36256) (comment: 00808_not_optimize_predicate.sql) (query 16, line 22) (in query: SELECT * FROM (SELECT id FROM test_00808 GROUP BY id LIMIT 1 BY id) WHERE id = 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/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>&&) @ 0x0000000015ce57cb 4. /build/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) @ 0x0000000016d4fa3f 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x0000000016d4f5b9 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x0000000016d4f3b2 7. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d571cc 8. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016cf6870 9. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 14. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 15. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 20. ? @ 0x00007f7210eb6ac3 21. ? @ 0x00007f7210f48850 2025.07.13 02:04:26.609394 [ 6637 ] {} TCPHandler: Code: 277. DB::Exception: Primary key (id, date) 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/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>&&) @ 0x0000000015ce57cb 4. /build/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) @ 0x0000000016d4fa3f 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x0000000016d4f5b9 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x0000000016d4f3b2 7. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d571cc 8. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016cf6870 9. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 14. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 15. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 20. ? @ 0x00007f7210eb6ac3 21. ? @ 0x00007f7210f48850 2025.07.13 02:04:27.251892 [ 6166 ] {d590e972-5f05-4ef4-adb2-7baac06b7048} executeQuery: Code: 36. DB::Exception: Engine Buffer doesn't support TTL clause. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36308) (comment: 02184_storage_add_support_ttl.sql) (query 13, line 15) (in query: ALTER TABLE buffer_02184 MODIFY COLUMN name String TTL dt + INTERVAL 1 MONTH;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/AlterCommands.cpp:1427: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015c148a1 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fcff4 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:04:27.268436 [ 6166 ] {} TCPHandler: Code: 36. DB::Exception: Engine Buffer doesn't support TTL clause. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/AlterCommands.cpp:1427: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015c148a1 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fcff4 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:04:28.092739 [ 6532 ] {f2ad0d35-fc27-428d-b512-ef13fccf4041} 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]:36402) (comment: 02699_polygons_sym_difference_total.sql) (query 1, line 1) (in query: SET enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:04:28.141159 [ 6532 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:04:28.391470 [ 6166 ] {cfefb68e-47c5-4249-9caa-6b62bec7bd50} executeQuery: Code: 36. DB::Exception: Engine Merge doesn't support TTL clause. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36308) (comment: 02184_storage_add_support_ttl.sql) (query 18, line 21) (in query: ALTER TABLE merge_02184 MODIFY COLUMN name String TTL dt + INTERVAL 1 MONTH;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/AlterCommands.cpp:1427: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015c148a1 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fcff4 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:04:28.405236 [ 6166 ] {} TCPHandler: Code: 36. DB::Exception: Engine Merge doesn't support TTL clause. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/AlterCommands.cpp:1427: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015c148a1 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fcff4 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:04:29.353370 [ 6166 ] {306708d9-e997-49ef-be90-3aeea087fb90} executeQuery: Code: 36. DB::Exception: Engine Null doesn't support TTL clause. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36308) (comment: 02184_storage_add_support_ttl.sql) (query 23, line 27) (in query: ALTER TABLE null_02184 MODIFY COLUMN dummy Int TTL now() + INTERVAL 1 MONTH;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/AlterCommands.cpp:1427: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015c148a1 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fcff4 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:04:29.365989 [ 6166 ] {} TCPHandler: Code: 36. DB::Exception: Engine Null doesn't support TTL clause. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/AlterCommands.cpp:1427: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015c148a1 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fcff4 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:04:30.206228 [ 6166 ] {add8b4cd-3a4b-427d-8dc8-b9d2dc7d01c9} executeQuery: Code: 36. DB::Exception: Engine File doesn't support TTL clause. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36308) (comment: 02184_storage_add_support_ttl.sql) (query 28, line 33) (in query: ALTER TABLE file_02184 MODIFY COLUMN name String TTL dt + INTERVAL 1 MONTH;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/AlterCommands.cpp:1427: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015c148a1 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fcff4 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:04:30.233681 [ 6166 ] {} TCPHandler: Code: 36. DB::Exception: Engine File doesn't support TTL clause. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/AlterCommands.cpp:1427: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015c148a1 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fcff4 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:04:31.010689 [ 6166 ] {ad1c88e4-93f5-4cbd-a3cc-ce024ffeb52e} executeQuery: Code: 36. DB::Exception: Engine Memory doesn't support TTL clause. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36308) (comment: 02184_storage_add_support_ttl.sql) (query 33, line 39) (in query: ALTER TABLE memory_02184 MODIFY COLUMN name String TTL dt + INTERVAL 1 MONTH;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/AlterCommands.cpp:1427: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015c148a1 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fcff4 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:04:31.031192 [ 6166 ] {} TCPHandler: Code: 36. DB::Exception: Engine Memory doesn't support TTL clause. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/AlterCommands.cpp:1427: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015c148a1 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fcff4 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:04:31.849042 [ 6166 ] {8eca6b3d-160f-42ea-85bb-8764030f6b56} executeQuery: Code: 36. DB::Exception: Engine Log doesn't support TTL clause. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36308) (comment: 02184_storage_add_support_ttl.sql) (query 38, line 45) (in query: ALTER TABLE log_02184 MODIFY COLUMN name String TTL dt + INTERVAL 1 MONTH;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/AlterCommands.cpp:1427: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015c148a1 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fcff4 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:04:31.875944 [ 6166 ] {} TCPHandler: Code: 36. DB::Exception: Engine Log doesn't support TTL clause. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/AlterCommands.cpp:1427: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015c148a1 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fcff4 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:04:32.851378 [ 6166 ] {8745a051-5ea5-42f1-9ec1-c784f0440924} executeQuery: Code: 36. DB::Exception: Engine TinyLog doesn't support TTL clause. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36308) (comment: 02184_storage_add_support_ttl.sql) (query 43, line 51) (in query: ALTER TABLE ting_log_02184 MODIFY COLUMN name String TTL dt + INTERVAL 1 MONTH;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/AlterCommands.cpp:1427: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015c148a1 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fcff4 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:04:32.877619 [ 6166 ] {} TCPHandler: Code: 36. DB::Exception: Engine TinyLog doesn't support TTL clause. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/AlterCommands.cpp:1427: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015c148a1 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fcff4 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:04:33.780681 [ 6166 ] {167dc2ec-be00-4c0b-b2d1-8e110649af71} executeQuery: Code: 36. DB::Exception: Engine StripeLog doesn't support TTL clause. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36308) (comment: 02184_storage_add_support_ttl.sql) (query 48, line 57) (in query: ALTER TABLE stripe_log_02184 MODIFY COLUMN name String TTL dt + INTERVAL 1 MONTH;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/AlterCommands.cpp:1427: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015c148a1 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fcff4 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:04:33.789626 [ 6166 ] {} TCPHandler: Code: 36. DB::Exception: Engine StripeLog doesn't support TTL clause. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/AlterCommands.cpp:1427: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015c148a1 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fcff4 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:04:36.359692 [ 3543 ] {948f20c2-60b8-4303-848b-5453243088de} 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]:37368) (comment: 01825_type_json_ephemeral.sql) (query 1, line 2) (in query: SET allow_experimental_object_type = 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:04:36.381004 [ 6614 ] {494581ac-04c7-4d6e-a125-4fc01fd02a4a} 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]:37376) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a59c08b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:5380: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x0000000016276974 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:241: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd450 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:04:36.413380 [ 3543 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:04:36.465077 [ 6614 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a59c08b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:5380: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x0000000016276974 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:241: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd450 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:04:41.591887 [ 6614 ] {e87b7abc-94da-4fac-8d84-87092ae33908} executeQuery: Code: 497. DB::Exception: test_1gye5vyt_restricted_user_60188224: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_1gye5vyt.dict: while executing 'FUNCTION dictGetString(__dictGetString :: 1, 'value' :: 2, key :: 0) -> dictGetString(test_1gye5vyt.dict, 'value', key) String : 5'. (ACCESS_DENIED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39662) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000136a8744 5. /build/src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x00000000136a7203 6. /build/src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x00000000136a6851 7. /build/src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x0000000013679004 8. /build/src/Access/ContextAccess.h:256: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000001434c694 9. /build/src/Functions/FunctionsExternalDictionaries.h:80: DB::FunctionDictHelper::getDictionary(String const&) @ 0x000000000a1148b4 10. /build/src/Functions/FunctionsExternalDictionaries.h:426: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a11185e 11. /build/src/Functions/FunctionsExternalDictionaries.h:831: DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a12d422 12. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 13. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 17. /build/src/Processors/Transforms/ExpressionTransform.cpp:41: DB::ConvertingTransform::onConsume(DB::Chunk) @ 0x0000000016b3074c 18. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 20. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 21. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 22. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 23. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 24. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000168e3c3f 25. /build/src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001681130c 26. /build/src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x0000000016806e9c 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:04:41.667250 [ 6614 ] {} TCPHandler: Code: 497. DB::Exception: test_1gye5vyt_restricted_user_60188224: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_1gye5vyt.dict: while executing 'FUNCTION dictGetString(__dictGetString :: 1, 'value' :: 2, key :: 0) -> dictGetString(test_1gye5vyt.dict, 'value', key) String : 5'. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000136a8744 5. /build/src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x00000000136a7203 6. /build/src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x00000000136a6851 7. /build/src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x0000000013679004 8. /build/src/Access/ContextAccess.h:256: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000001434c694 9. /build/src/Functions/FunctionsExternalDictionaries.h:80: DB::FunctionDictHelper::getDictionary(String const&) @ 0x000000000a1148b4 10. /build/src/Functions/FunctionsExternalDictionaries.h:426: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a11185e 11. /build/src/Functions/FunctionsExternalDictionaries.h:831: DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a12d422 12. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 13. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 17. /build/src/Processors/Transforms/ExpressionTransform.cpp:41: DB::ConvertingTransform::onConsume(DB::Chunk) @ 0x0000000016b3074c 18. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 20. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 21. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 22. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 23. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 24. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000168e3c3f 25. /build/src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001681130c 26. /build/src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x0000000016806e9c 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:04:42.434159 [ 5806 ] {a1cbc706-4fdd-4666-a0c5-90104b3cd1e5} executeQuery: Code: 497. DB::Exception: test_1gye5vyt_restricted_user_60188224: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_1gye5vyt.dict: while executing 'FUNCTION dictGetString(__dictGetString :: 1, 'value' :: 2, key :: 0) -> dictGetString(test_1gye5vyt.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_1gye5vyt.table_with_default (key) FORMAT Values), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000136a8744 5. /build/src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x00000000136a7203 6. /build/src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x00000000136a6851 7. /build/src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x0000000013679004 8. /build/src/Access/ContextAccess.h:256: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000001434c694 9. /build/src/Functions/FunctionsExternalDictionaries.h:80: DB::FunctionDictHelper::getDictionary(String const&) @ 0x000000000a1148b4 10. /build/src/Functions/FunctionsExternalDictionaries.h:426: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a11185e 11. /build/src/Functions/FunctionsExternalDictionaries.h:831: DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a12d422 12. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 13. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 17. /build/src/Processors/Transforms/ExpressionTransform.cpp:41: DB::ConvertingTransform::onConsume(DB::Chunk) @ 0x0000000016b3074c 18. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 20. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 21. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 22. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 23. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 24. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 25. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 26. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000168cfa64 27. /build/src/Interpreters/AsynchronousInsertQueue.cpp:996: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x00000000143021bc 28. /build/src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:se190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000014305104 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 30. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 31. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 2025.07.13 02:04:42.449871 [ 5806 ] {} AsynchronousInsertQueue: Failed insertion for query 'INSERT INTO test_1gye5vyt.table_with_default (key) FORMAT Values': Code: 497. DB::Exception: test_1gye5vyt_restricted_user_60188224: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_1gye5vyt.dict: while executing 'FUNCTION dictGetString(__dictGetString :: 1, 'value' :: 2, key :: 0) -> dictGetString(test_1gye5vyt.dict, 'value', key) String : 5'. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000136a8744 5. /build/src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x00000000136a7203 6. /build/src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x00000000136a6851 7. /build/src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x0000000013679004 8. /build/src/Access/ContextAccess.h:256: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000001434c694 9. /build/src/Functions/FunctionsExternalDictionaries.h:80: DB::FunctionDictHelper::getDictionary(String const&) @ 0x000000000a1148b4 10. /build/src/Functions/FunctionsExternalDictionaries.h:426: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a11185e 11. /build/src/Functions/FunctionsExternalDictionaries.h:831: DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a12d422 12. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 13. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 17. /build/src/Processors/Transforms/ExpressionTransform.cpp:41: DB::ConvertingTransform::onConsume(DB::Chunk) @ 0x0000000016b3074c 18. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 20. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 21. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 22. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 23. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 24. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 25. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 26. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000168cfa64 27. /build/src/Interpreters/AsynchronousInsertQueue.cpp:996: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x00000000143021bc 28. /build/src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:se190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000014305104 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 30. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 31. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:04:42.550161 [ 3543 ] {7a2bbfbc-6f81-46c6-91dc-4462f941b56f} executeQuery: Code: 497. DB::Exception: test_1gye5vyt_restricted_user_60188224: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_1gye5vyt.dict: while executing 'FUNCTION dictGetString(__dictGetString :: 1, 'value' :: 2, key :: 0) -> dictGetString(test_1gye5vyt.dict, 'value', key) String : 5': While executing WaitForAsyncInsert. (ACCESS_DENIED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39686) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000136a8744 5. /build/src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x00000000136a7203 6. /build/src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x00000000136a6851 7. /build/src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x0000000013679004 8. /build/src/Access/ContextAccess.h:256: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000001434c694 9. /build/src/Functions/FunctionsExternalDictionaries.h:80: DB::FunctionDictHelper::getDictionary(String const&) @ 0x000000000a1148b4 10. /build/src/Functions/FunctionsExternalDictionaries.h:426: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a11185e 11. /build/src/Functions/FunctionsExternalDictionaries.h:831: DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a12d422 12. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 13. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 17. /build/src/Processors/Transforms/ExpressionTransform.cpp:41: DB::ConvertingTransform::onConsume(DB::Chunk) @ 0x0000000016b3074c 18. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 20. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 21. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 22. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 23. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 24. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 25. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 26. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000168cfa64 27. /build/src/Interpreters/AsynchronousInsertQueue.cpp:996: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x00000000143021bc 28. /build/src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:se190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000014305104 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 30. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 31. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 2025.07.13 02:04:42.570675 [ 3543 ] {} TCPHandler: Code: 497. DB::Exception: test_1gye5vyt_restricted_user_60188224: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_1gye5vyt.dict: while executing 'FUNCTION dictGetString(__dictGetString :: 1, 'value' :: 2, key :: 0) -> dictGetString(test_1gye5vyt.dict, 'value', key) String : 5': While executing WaitForAsyncInsert. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000136a8744 5. /build/src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x00000000136a7203 6. /build/src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x00000000136a6851 7. /build/src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x0000000013679004 8. /build/src/Access/ContextAccess.h:256: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000001434c694 9. /build/src/Functions/FunctionsExternalDictionaries.h:80: DB::FunctionDictHelper::getDictionary(String const&) @ 0x000000000a1148b4 10. /build/src/Functions/FunctionsExternalDictionaries.h:426: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a11185e 11. /build/src/Functions/FunctionsExternalDictionaries.h:831: DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a12d422 12. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 13. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 17. /build/src/Processors/Transforms/ExpressionTransform.cpp:41: DB::ConvertingTransform::onConsume(DB::Chunk) @ 0x0000000016b3074c 18. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 20. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 21. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 22. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 23. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 24. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 25. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 26. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000168cfa64 27. /build/src/Interpreters/AsynchronousInsertQueue.cpp:996: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x00000000143021bc 28. /build/src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:se190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000014305104 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 30. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 31. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 2025.07.13 02:04:48.120697 [ 3542 ] {a7b96153-c92f-4137-8bb9-95738755e8bb} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=850, jobs=796). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36362) (comment: 02932_apply_deleted_mask.sql) (query 11, line 20) (in query: SELECT count(), sum(rows), sum(has_lightweight_delete) FROM system.parts WHERE database = currentDatabase() AND table = 't_materialize_delete' AND active;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbdd1d3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd751c 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 9. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 10. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:04:48.145261 [ 3542 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=850, jobs=796). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbdd1d3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd751c 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 9. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 10. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:04:48.219838 [ 3971 ] {} DNSResolver: Cannot resolve host (localhos), error 0: Host not found. 2025.07.13 02:04:51.877512 [ 5823 ] {} test_mz7e5yrq.t_materialize_delete (2fc134b1-c967-4bde-8c34-fa1b8b10caad): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.07.13 02:04:52.255169 [ 5823 ] {} DatabaseCatalog: Cannot drop table test_mz7e5yrq.t_materialize_delete (2fc134b1-c967-4bde-8c34-fa1b8b10caad). Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda7a6 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000118cbf6e 8. /build/src/Storages/MergeTree/MergeTreeData.cpp:2942: DB::MergeTreeData::clearPartsFromFilesystemImplMaybeInParallel(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>*) @ 0x000000001624b6d4 9. /build/src/Storages/MergeTree/MergeTreeData.cpp:2879: DB::MergeTreeData::clearPartsFromFilesystemImpl(std::vector, std::allocator>> const&, bool, std::unordered_set, std::equal_to, std::allocator>*) @ 0x000000001624a7c0 10. /build/src/Storages/MergeTree/MergeTreeData.cpp:3285: DB::MergeTreeData::dropAllData() @ 0x0000000016252347 11. /build/src/Interpreters/DatabaseCatalog.cpp:1400: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x000000001442196e 12. /build/src/Interpreters/DatabaseCatalog.cpp:1323: void std::__function::__policy_invoker::__call_impl[abi:se190107], std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000001442a011 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000118cc9d0 14. /build/src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x00000000118cc7fb 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 18. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:04:53.494569 [ 6532 ] {ba15e7b4-4dfb-4b3a-a047-73dca5d02590} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=850, jobs=798). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37222) (comment: 01056_predicate_optimizer_bugs.sql) (query 27, line 41) (in query: -- https://github.com/ClickHouse/ClickHouse/issues/7136 EXPLAIN SYNTAX SELECT ccc FROM ( SELECT 1 AS ccc UNION ALL SELECT * FROM ( SELECT 2 AS ccc ) ANY INNER JOIN ( SELECT 2 AS ccc ) USING (ccc) ) WHERE ccc > 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbdd1d3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd751c 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 9. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 10. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:04:53.522265 [ 6532 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=850, jobs=798). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbdd1d3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd751c 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 9. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 10. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:04:54.424762 [ 6611 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778c58 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168167bf 10. /build/src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000001680ff45 11. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:04:54.458076 [ 6611 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x0000000016810069 5. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 6. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 2025.07.13 02:04:56.239955 [ 5121 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000013779f8b 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000137794b8 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778bc3 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678d325 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:05.706391 [ 6637 ] {54982254-9742-4a55-9ba0-f505f0b376a2} 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]:51348) (comment: 03032_string_to_variant_cast.sql) (query 7, line 7) (in query: select CAST('42', 'Variant(Date)') as v, variantType(v);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&) @ 0x000000000fd73e4b 4. /build/src/DataTypes/Serializations/SerializationVariant.cpp:1060: DB::SerializationVariant::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013c5a991 5. /build/src/Functions/FunctionsConversion.h:1922: DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x0000000012cd3b4b 6. /build/src/Functions/FunctionsConversion.h:1894: DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000012cd266d 7. /build/src/Functions/FunctionsConversion.h:5145: DB::detail::FunctionCast::createStringToVariantWrapper() const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x0000000012cd42b8 8. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000012cd4089 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012cc745b 10. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fc534a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 14. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f75b 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:05:05.723150 [ 6637 ] {} TCPHandler: Code: 117. DB::Exception: Cannot parse text value of type Variant(Date) here: 42: In scope SELECT CAST('42', 'Variant(Date)') AS v, variantType(v). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&) @ 0x000000000fd73e4b 4. /build/src/DataTypes/Serializations/SerializationVariant.cpp:1060: DB::SerializationVariant::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013c5a991 5. /build/src/Functions/FunctionsConversion.h:1922: DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x0000000012cd3b4b 6. /build/src/Functions/FunctionsConversion.h:1894: DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000012cd266d 7. /build/src/Functions/FunctionsConversion.h:5145: DB::detail::FunctionCast::createStringToVariantWrapper() const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x0000000012cd42b8 8. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000012cd4089 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012cc745b 10. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fc534a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 14. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f75b 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:05:10.431383 [ 6608 ] {f8e16123-05f9-44af-8ab8-275c8c95044b} executeQuery: Code: 57. DB::Exception: Table test_vsgafcwe.tbl already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52122) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:05:10.451819 [ 6608 ] {} TCPHandler: Code: 57. DB::Exception: Table test_vsgafcwe.tbl already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:05:10.526240 [ 5872 ] {6333a1a0-321c-402a-bf00-f3e0e8381e4e} 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]:52120) (comment: 02520_group_array_last.sql) (query 2, line 3) (in query: -- { echo } -- BAD_ARGUMENTS select groupArrayLast(number+1) from numbers(5);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/AggregateFunctions/AggregateFunctionGroupArray.cpp:802: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000001007976d 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130caa1d 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:05:10.555833 [ 5872 ] {} TCPHandler: Code: 36. DB::Exception: groupArrayLast make sense only with max_elems (groupArrayLast(max_elems)()). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/AggregateFunctions/AggregateFunctionGroupArray.cpp:802: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000001007976d 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130caa1d 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:05:10.939946 [ 5872 ] {1d3df069-9818-4c01-abdd-3fe623309410} 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]:52120) (comment: 02520_group_array_last.sql) (query 3, line 6) (in query: select groupArrayLastArray([number+1]) from numbers(5);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/AggregateFunctions/AggregateFunctionGroupArray.cpp:802: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000001007976d 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130caa1d 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 7. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:253: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000130ca98b 8. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:05:10.953343 [ 5872 ] {} TCPHandler: Code: 36. DB::Exception: groupArrayLast make sense only with max_elems (groupArrayLast(max_elems)()). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/AggregateFunctions/AggregateFunctionGroupArray.cpp:802: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000001007976d 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130caa1d 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 7. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:253: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000130ca98b 8. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:05:11.264721 [ 3635 ] {} DNSResolver: Cannot resolve host (localhos), error 0: Host not found. 2025.07.13 02:05:13.030699 [ 3899 ] {} test_gqywdoo2.rmt_slave (1851a938-6eec-4d9c-802e-a400081f71ea): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 236. DB::Exception: Log pulling is cancelled. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:924: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x00000000164ed68b 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:3833: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x0000000015e1b9b8 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013882414 7. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000138854aa 8. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000013885c47 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:13.174373 [ 3596 ] {} test_gqywdoo2.rmt_slave (1851a938-6eec-4d9c-802e-a400081f71ea): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 236. DB::Exception: Log pulling is cancelled. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:638: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x00000000164e8312 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:3798: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x0000000015e1b62b 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013882414 7. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000138854aa 8. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000013885c47 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:13.369608 [ 3543 ] {2b20412e-b386-440d-a90e-5a234fe1f34d} 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]:45036) (comment: 02561_null_as_default_more_formats.sh) (in query: DROP DATABASE IF EXISTS test_gqvrj4b8 SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:05:13.372617 [ 3543 ] {2b20412e-b386-440d-a90e-5a234fe1f34d} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:13.682205 [ 6614 ] {a6746ffb-f015-4961-aeed-2e1d66ffdc15} 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]:45048) (comment: 02561_null_as_default_more_formats.sh) (in query: DROP DATABASE IF EXISTS test_gqvrj4b8 SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:05:13.692993 [ 6614 ] {a6746ffb-f015-4961-aeed-2e1d66ffdc15} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:14.044484 [ 4079 ] {} test_gqywdoo2.rmt_slave (1851a938-6eec-4d9c-802e-a400081f71ea): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 236. DB::Exception: Log pulling is cancelled. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:924: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x00000000164ed68b 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:3833: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x0000000015e1b9b8 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013882414 7. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000138854aa 8. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000013885c47 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:14.185286 [ 3674 ] {} test_gqywdoo2.rmt_slave (1851a938-6eec-4d9c-802e-a400081f71ea): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 236. DB::Exception: Log pulling is cancelled. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:638: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x00000000164e8312 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:3798: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x0000000015e1b62b 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013882414 7. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000138854aa 8. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000013885c47 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:14.449182 [ 5998 ] {bd245c2c-e261-4159-b49a-aeadac6f0636} 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]:45068) (comment: 02047_log_family_data_file_sizes.sh) (in query: DROP DATABASE IF EXISTS test_vsgafcwe SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:05:14.455818 [ 5998 ] {bd245c2c-e261-4159-b49a-aeadac6f0636} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:15.067129 [ 3996 ] {} test_gqywdoo2.rmt_slave (1851a938-6eec-4d9c-802e-a400081f71ea): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 236. DB::Exception: Log pulling is cancelled. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:924: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x00000000164ed68b 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:3833: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x0000000015e1b9b8 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013882414 7. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000138854aa 8. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000013885c47 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:15.194768 [ 3634 ] {} test_gqywdoo2.rmt_slave (1851a938-6eec-4d9c-802e-a400081f71ea): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 236. DB::Exception: Log pulling is cancelled. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:638: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x00000000164e8312 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:3798: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x0000000015e1b62b 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013882414 7. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000138854aa 8. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000013885c47 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:16.074619 [ 4009 ] {} test_gqywdoo2.rmt_slave (1851a938-6eec-4d9c-802e-a400081f71ea): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 236. DB::Exception: Log pulling is cancelled. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:924: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x00000000164ed68b 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:3833: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x0000000015e1b9b8 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013882414 7. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000138854aa 8. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000013885c47 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:16.168169 [ 6615 ] {eb6f057c-07a8-4637-92a6-5630753b91b5} executeQuery: Code: 80. DB::Exception: Direct creation of tables with ENGINE Loop is not supported, use Loop as a table function only. (INCORRECT_QUERY) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 03307_forbid_loop_table_function_as_engine.sql) (in query: /* ddl_entry=query-0000000002 */ CREATE TABLE test_m0oxum4u.tab UUID 'be758cd8-0e98-4318-ae22-7d52f14886bb' (`col` String) ENGINE = Loop), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Storages/StorageFactory.cpp:142: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x0000000015ca2a19 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001481ee32 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 9. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 10. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 11. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 12. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 13. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:05:16.213520 [ 3600 ] {} test_gqywdoo2.rmt_slave (1851a938-6eec-4d9c-802e-a400081f71ea): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 236. DB::Exception: Log pulling is cancelled. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:638: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x00000000164e8312 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:3798: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x0000000015e1b62b 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013882414 7. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000138854aa 8. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000013885c47 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:16.232155 [ 6615 ] {eb6f057c-07a8-4637-92a6-5630753b91b5} executeQuery: Code: 80. DB::Exception: Direct creation of tables with ENGINE Loop is not supported, use Loop as a table function only. (INCORRECT_QUERY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52320) (comment: 03307_forbid_loop_table_function_as_engine.sql) (query 1, line 1) (in query: CREATE TABLE tab (col String) ENGINE=Loop;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Storages/StorageFactory.cpp:142: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x0000000015ca2a19 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001481ee32 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 9. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 10. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 11. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 12. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 13. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:05:16.248474 [ 6615 ] {} TCPHandler: Code: 80. DB::Exception: Direct creation of tables with ENGINE Loop is not supported, use Loop as a table function only. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Storages/StorageFactory.cpp:142: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x0000000015ca2a19 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001481ee32 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 9. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 10. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 11. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 12. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 13. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:05:16.959046 [ 6637 ] {d3867d50-3472-4d91-b5fb-7412f54a72f6} 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]:52072) (comment: 03224_nested_json_merges_new_type_in_shared_data.sql) (query 9, line 10) (in query: optimize table test final;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000000fb2dc4b 4. /build/src/Common/MemoryTracker.cpp:196: MemoryTracker::injectFault() const @ 0x000000000fb2b6cd 5. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:153: DB::MergePlainMergeTreeTask::finish() @ 0x0000000016593639 6. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:72: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000016592af2 7. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x0000000016564e9a 8. /build/src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000001656bb83 9. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014bf58ce 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:05:17.042326 [ 6637 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000000fb2dc4b 4. /build/src/Common/MemoryTracker.cpp:196: MemoryTracker::injectFault() const @ 0x000000000fb2b6cd 5. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:153: DB::MergePlainMergeTreeTask::finish() @ 0x0000000016593639 6. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:72: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000016592af2 7. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x0000000016564e9a 8. /build/src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000001656bb83 9. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014bf58ce 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:05:17.083176 [ 3830 ] {} test_gqywdoo2.rmt_slave (1851a938-6eec-4d9c-802e-a400081f71ea): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 236. DB::Exception: Log pulling is cancelled. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:924: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x00000000164ed68b 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:3833: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x0000000015e1b9b8 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013882414 7. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000138854aa 8. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000013885c47 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:17.223839 [ 4072 ] {} test_gqywdoo2.rmt_slave (1851a938-6eec-4d9c-802e-a400081f71ea): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 236. DB::Exception: Log pulling is cancelled. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:638: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x00000000164e8312 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:3798: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x0000000015e1b62b 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013882414 7. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000138854aa 8. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000013885c47 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:17.578570 [ 6611 ] {6f15d16d-085a-42f0-a86a-ea9afea74ee9} 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]:52354) (comment: 01825_type_json_partitions.sql) (query 2, line 5) (in query: SET allow_experimental_object_type = 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:05:17.591223 [ 6611 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:05:18.097234 [ 3762 ] {} test_gqywdoo2.rmt_slave (1851a938-6eec-4d9c-802e-a400081f71ea): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 236. DB::Exception: Log pulling is cancelled. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:924: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x00000000164ed68b 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:3833: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x0000000015e1b9b8 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013882414 7. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000138854aa 8. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000013885c47 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:18.253328 [ 3895 ] {} test_gqywdoo2.rmt_slave (1851a938-6eec-4d9c-802e-a400081f71ea): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 236. DB::Exception: Log pulling is cancelled. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:638: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x00000000164e8312 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:3798: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x0000000015e1b62b 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013882414 7. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000138854aa 8. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000013885c47 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:19.113084 [ 3654 ] {} test_gqywdoo2.rmt_slave (1851a938-6eec-4d9c-802e-a400081f71ea): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 236. DB::Exception: Log pulling is cancelled. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:924: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x00000000164ed68b 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:3833: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x0000000015e1b9b8 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013882414 7. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000138854aa 8. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000013885c47 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:19.295931 [ 3968 ] {} test_gqywdoo2.rmt_slave (1851a938-6eec-4d9c-802e-a400081f71ea): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 236. DB::Exception: Log pulling is cancelled. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:638: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x00000000164e8312 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:3798: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x0000000015e1b62b 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013882414 7. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000138854aa 8. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000013885c47 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:19.508488 [ 6608 ] {f454420b-ce19-4feb-9d8e-ad2171cff0fb} executeQuery: Code: 632. DB::Exception: Unexpected data 'trash' after parsed Array value '[1,2,3]': (while reading the value of key x): (in file/uri /var/lib/clickhouse/user_files/test_i57376yt): While executing JSONCompactEachRowRowInputFormat: While executing File. (UNEXPECTED_DATA_AFTER_PARSED_VALUE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52368) (comment: 02118_deserialize_whole_text.sh) (query 1, line 1) (in query: SELECT * FROM file('test_i57376yt', 'JSONCompactStringsEachRow', 'x Array(UInt32)')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&) @ 0x00000000138567eb 4. /build/src/DataTypes/Serializations/ISerialization.cpp:499: DB::ISerialization::throwUnexpectedDataAfterParsedValue(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, String const&) const @ 0x0000000013ba210b 5. /build/src/DataTypes/Serializations/SerializationArray.cpp:543: DB::SerializationArray::deserializeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x0000000013baa793 6. /build/src/DataTypes/Serializations/SerializationNullable.cpp:597: void DB::deserializeWholeTextImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x0000000013bf5ed4 7. /build/src/DataTypes/Serializations/SerializationNullable.cpp:622: DB::SerializationNullable::deserializeNullAsDefaultOrNestedWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000013bf478b 8. /build/src/Formats/JSONUtils.cpp:286: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x0000000016888f7d 9. /build/src/Processors/Formats/Impl/JSONCompactEachRowRowInputFormat.cpp:132: DB::JSONCompactEachRowFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000169e9eac 10. /build/src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001696565c 11. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016940972 12. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 13. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 14. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 18. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 19. /build/src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000015cae3aa 20. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 21. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 22. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 23. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 24. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 25. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:05:19.622974 [ 6608 ] {} TCPHandler: Code: 632. DB::Exception: Unexpected data 'trash' after parsed Array value '[1,2,3]': (while reading the value of key x): (in file/uri /var/lib/clickhouse/user_files/test_i57376yt): While executing JSONCompactEachRowRowInputFormat: While executing File. (UNEXPECTED_DATA_AFTER_PARSED_VALUE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&) @ 0x00000000138567eb 4. /build/src/DataTypes/Serializations/ISerialization.cpp:499: DB::ISerialization::throwUnexpectedDataAfterParsedValue(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, String const&) const @ 0x0000000013ba210b 5. /build/src/DataTypes/Serializations/SerializationArray.cpp:543: DB::SerializationArray::deserializeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x0000000013baa793 6. /build/src/DataTypes/Serializations/SerializationNullable.cpp:597: void DB::deserializeWholeTextImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x0000000013bf5ed4 7. /build/src/DataTypes/Serializations/SerializationNullable.cpp:622: DB::SerializationNullable::deserializeNullAsDefaultOrNestedWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000013bf478b 8. /build/src/Formats/JSONUtils.cpp:286: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x0000000016888f7d 9. /build/src/Processors/Formats/Impl/JSONCompactEachRowRowInputFormat.cpp:132: DB::JSONCompactEachRowFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000169e9eac 10. /build/src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001696565c 11. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016940972 12. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 13. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 14. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 18. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 19. /build/src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000015cae3aa 20. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 21. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 22. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 23. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 24. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 25. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:05:20.127421 [ 3770 ] {} test_gqywdoo2.rmt_slave (1851a938-6eec-4d9c-802e-a400081f71ea): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 236. DB::Exception: Log pulling is cancelled. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:924: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x00000000164ed68b 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:3833: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x0000000015e1b9b8 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013882414 7. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000138854aa 8. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000013885c47 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:20.359544 [ 3726 ] {} test_gqywdoo2.rmt_slave (1851a938-6eec-4d9c-802e-a400081f71ea): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 236. DB::Exception: Log pulling is cancelled. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:638: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x00000000164e8312 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:3798: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x0000000015e1b62b 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013882414 7. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000138854aa 8. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000013885c47 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:20.523759 [ 6608 ] {3e55db39-3427-4f1e-ad2d-58c6d74a8051} executeQuery: Code: 632. DB::Exception: Unexpected data 'trash' after parsed Date value '1970-01-02': (while reading the value of key x): (in file/uri /var/lib/clickhouse/user_files/test_i57376yt): While executing JSONCompactEachRowRowInputFormat: While executing File. (UNEXPECTED_DATA_AFTER_PARSED_VALUE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40666) (comment: 02118_deserialize_whole_text.sh) (query 1, line 1) (in query: SELECT * FROM file('test_i57376yt', 'JSONCompactStringsEachRow', 'x Date')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&) @ 0x00000000138567eb 4. /build/src/DataTypes/Serializations/ISerialization.cpp:499: DB::ISerialization::throwUnexpectedDataAfterParsedValue(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, String const&) const @ 0x0000000013ba210b 5. /build/src/DataTypes/Serializations/SerializationDate.cpp:22: DB::SerializationDate::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013bb0f4a 6. /build/src/DataTypes/Serializations/SerializationNullable.cpp:597: void DB::deserializeWholeTextImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x0000000013bf5ed4 7. /build/src/DataTypes/Serializations/SerializationNullable.cpp:622: DB::SerializationNullable::deserializeNullAsDefaultOrNestedWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000013bf478b 8. /build/src/Formats/JSONUtils.cpp:286: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x0000000016888f7d 9. /build/src/Processors/Formats/Impl/JSONCompactEachRowRowInputFormat.cpp:132: DB::JSONCompactEachRowFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000169e9eac 10. /build/src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001696565c 11. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016940972 12. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 13. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 14. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 18. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 19. /build/src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000015cae3aa 20. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 21. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 22. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 23. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 24. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 25. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:05:20.687132 [ 6608 ] {} TCPHandler: Code: 632. DB::Exception: Unexpected data 'trash' after parsed Date value '1970-01-02': (while reading the value of key x): (in file/uri /var/lib/clickhouse/user_files/test_i57376yt): While executing JSONCompactEachRowRowInputFormat: While executing File. (UNEXPECTED_DATA_AFTER_PARSED_VALUE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&) @ 0x00000000138567eb 4. /build/src/DataTypes/Serializations/ISerialization.cpp:499: DB::ISerialization::throwUnexpectedDataAfterParsedValue(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, String const&) const @ 0x0000000013ba210b 5. /build/src/DataTypes/Serializations/SerializationDate.cpp:22: DB::SerializationDate::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013bb0f4a 6. /build/src/DataTypes/Serializations/SerializationNullable.cpp:597: void DB::deserializeWholeTextImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x0000000013bf5ed4 7. /build/src/DataTypes/Serializations/SerializationNullable.cpp:622: DB::SerializationNullable::deserializeNullAsDefaultOrNestedWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000013bf478b 8. /build/src/Formats/JSONUtils.cpp:286: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x0000000016888f7d 9. /build/src/Processors/Formats/Impl/JSONCompactEachRowRowInputFormat.cpp:132: DB::JSONCompactEachRowFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000169e9eac 10. /build/src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001696565c 11. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016940972 12. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 13. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 14. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 18. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 19. /build/src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000015cae3aa 20. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 21. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 22. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 23. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 24. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 25. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:05:21.140866 [ 3884 ] {} test_gqywdoo2.rmt_slave (1851a938-6eec-4d9c-802e-a400081f71ea): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 236. DB::Exception: Log pulling is cancelled. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:924: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x00000000164ed68b 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:3833: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x0000000015e1b9b8 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013882414 7. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000138854aa 8. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000013885c47 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:21.374018 [ 4077 ] {} test_gqywdoo2.rmt_slave (1851a938-6eec-4d9c-802e-a400081f71ea): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 236. DB::Exception: Log pulling is cancelled. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:638: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x00000000164e8312 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:3798: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x0000000015e1b62b 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013882414 7. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000138854aa 8. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000013885c47 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:21.697134 [ 6608 ] {e03a383a-4abf-42f6-bfe6-a96c7c2441f7} executeQuery: Code: 632. DB::Exception: Unexpected data 'trash' after parsed Date32 value '1970-01-02': (while reading the value of key x): (in file/uri /var/lib/clickhouse/user_files/test_i57376yt): While executing JSONCompactEachRowRowInputFormat: While executing File. (UNEXPECTED_DATA_AFTER_PARSED_VALUE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40704) (comment: 02118_deserialize_whole_text.sh) (query 1, line 1) (in query: SELECT * FROM file('test_i57376yt', 'JSONCompactStringsEachRow', 'x Date32')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&) @ 0x00000000138567eb 4. /build/src/DataTypes/Serializations/ISerialization.cpp:499: DB::ISerialization::throwUnexpectedDataAfterParsedValue(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, String const&) const @ 0x0000000013ba210b 5. /build/src/DataTypes/Serializations/SerializationDate32.cpp:21: DB::SerializationDate32::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013bb238a 6. /build/src/DataTypes/Serializations/SerializationNullable.cpp:597: void DB::deserializeWholeTextImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x0000000013bf5ed4 7. /build/src/DataTypes/Serializations/SerializationNullable.cpp:622: DB::SerializationNullable::deserializeNullAsDefaultOrNestedWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000013bf478b 8. /build/src/Formats/JSONUtils.cpp:286: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x0000000016888f7d 9. /build/src/Processors/Formats/Impl/JSONCompactEachRowRowInputFormat.cpp:132: DB::JSONCompactEachRowFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000169e9eac 10. /build/src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001696565c 11. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016940972 12. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 13. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 14. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 18. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 19. /build/src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000015cae3aa 20. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 21. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 22. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 23. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 24. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 25. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:05:21.741979 [ 6608 ] {} TCPHandler: Code: 632. DB::Exception: Unexpected data 'trash' after parsed Date32 value '1970-01-02': (while reading the value of key x): (in file/uri /var/lib/clickhouse/user_files/test_i57376yt): While executing JSONCompactEachRowRowInputFormat: While executing File. (UNEXPECTED_DATA_AFTER_PARSED_VALUE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&) @ 0x00000000138567eb 4. /build/src/DataTypes/Serializations/ISerialization.cpp:499: DB::ISerialization::throwUnexpectedDataAfterParsedValue(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, String const&) const @ 0x0000000013ba210b 5. /build/src/DataTypes/Serializations/SerializationDate32.cpp:21: DB::SerializationDate32::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013bb238a 6. /build/src/DataTypes/Serializations/SerializationNullable.cpp:597: void DB::deserializeWholeTextImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x0000000013bf5ed4 7. /build/src/DataTypes/Serializations/SerializationNullable.cpp:622: DB::SerializationNullable::deserializeNullAsDefaultOrNestedWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000013bf478b 8. /build/src/Formats/JSONUtils.cpp:286: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x0000000016888f7d 9. /build/src/Processors/Formats/Impl/JSONCompactEachRowRowInputFormat.cpp:132: DB::JSONCompactEachRowFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000169e9eac 10. /build/src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001696565c 11. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016940972 12. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 13. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 14. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 18. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 19. /build/src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000015cae3aa 20. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 21. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 22. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 23. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 24. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 25. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:05:22.153468 [ 3819 ] {} test_gqywdoo2.rmt_slave (1851a938-6eec-4d9c-802e-a400081f71ea): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 236. DB::Exception: Log pulling is cancelled. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:924: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x00000000164ed68b 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:3833: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x0000000015e1b9b8 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013882414 7. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000138854aa 8. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000013885c47 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:22.384375 [ 3834 ] {} test_gqywdoo2.rmt_slave (1851a938-6eec-4d9c-802e-a400081f71ea): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 236. DB::Exception: Log pulling is cancelled. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:638: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x00000000164e8312 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:3798: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x0000000015e1b62b 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013882414 7. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000138854aa 8. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000013885c47 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:22.964838 [ 6608 ] {2bbc58eb-ccdf-42fd-8df7-f5df1c5fcc9d} executeQuery: Code: 632. DB::Exception: Unexpected data 'trash' after parsed DateTime value '1970-01-01 03:00:01': (while reading the value of key x): (in file/uri /var/lib/clickhouse/user_files/test_i57376yt): While executing JSONCompactEachRowRowInputFormat: While executing File. (UNEXPECTED_DATA_AFTER_PARSED_VALUE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40720) (comment: 02118_deserialize_whole_text.sh) (query 1, line 1) (in query: SELECT * FROM file('test_i57376yt', 'JSONCompactStringsEachRow', 'x DateTime')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&) @ 0x00000000138567eb 4. /build/src/DataTypes/Serializations/ISerialization.cpp:499: DB::ISerialization::throwUnexpectedDataAfterParsedValue(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, String const&) const @ 0x0000000013ba210b 5. /build/src/DataTypes/Serializations/SerializationDateTime.cpp:104: DB::SerializationDateTime::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013bb378a 6. /build/src/DataTypes/Serializations/SerializationNullable.cpp:597: void DB::deserializeWholeTextImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x0000000013bf5ed4 7. /build/src/DataTypes/Serializations/SerializationNullable.cpp:622: DB::SerializationNullable::deserializeNullAsDefaultOrNestedWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000013bf478b 8. /build/src/Formats/JSONUtils.cpp:286: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x0000000016888f7d 9. /build/src/Processors/Formats/Impl/JSONCompactEachRowRowInputFormat.cpp:132: DB::JSONCompactEachRowFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000169e9eac 10. /build/src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001696565c 11. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016940972 12. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 13. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 14. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 18. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 19. /build/src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000015cae3aa 20. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 21. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 22. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 23. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 24. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 25. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:05:23.096677 [ 6608 ] {} TCPHandler: Code: 632. DB::Exception: Unexpected data 'trash' after parsed DateTime value '1970-01-01 03:00:01': (while reading the value of key x): (in file/uri /var/lib/clickhouse/user_files/test_i57376yt): While executing JSONCompactEachRowRowInputFormat: While executing File. (UNEXPECTED_DATA_AFTER_PARSED_VALUE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&) @ 0x00000000138567eb 4. /build/src/DataTypes/Serializations/ISerialization.cpp:499: DB::ISerialization::throwUnexpectedDataAfterParsedValue(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, String const&) const @ 0x0000000013ba210b 5. /build/src/DataTypes/Serializations/SerializationDateTime.cpp:104: DB::SerializationDateTime::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013bb378a 6. /build/src/DataTypes/Serializations/SerializationNullable.cpp:597: void DB::deserializeWholeTextImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x0000000013bf5ed4 7. /build/src/DataTypes/Serializations/SerializationNullable.cpp:622: DB::SerializationNullable::deserializeNullAsDefaultOrNestedWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000013bf478b 8. /build/src/Formats/JSONUtils.cpp:286: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x0000000016888f7d 9. /build/src/Processors/Formats/Impl/JSONCompactEachRowRowInputFormat.cpp:132: DB::JSONCompactEachRowFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000169e9eac 10. /build/src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001696565c 11. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016940972 12. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 13. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 14. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 18. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 19. /build/src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000015cae3aa 20. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 21. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 22. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 23. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 24. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 25. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:05:23.186255 [ 3750 ] {} test_gqywdoo2.rmt_slave (1851a938-6eec-4d9c-802e-a400081f71ea): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 236. DB::Exception: Log pulling is cancelled. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:924: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x00000000164ed68b 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:3833: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x0000000015e1b9b8 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013882414 7. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000138854aa 8. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000013885c47 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:23.393028 [ 3915 ] {} test_gqywdoo2.rmt_slave (1851a938-6eec-4d9c-802e-a400081f71ea): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 236. DB::Exception: Log pulling is cancelled. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:638: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x00000000164e8312 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:3798: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x0000000015e1b62b 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013882414 7. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000138854aa 8. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000013885c47 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:23.459359 [ 5998 ] {cde0c0aa-f9ab-475b-8942-d532b46eaecb} executeQuery: Code: 561. DB::Exception: ZSTD stream decoding failed: error 'Frame requires too much memory for decoding'; ZSTD version: 1.5.7: While reading from: /var/lib/clickhouse/user_files/test_02961_1752365118952639.csv: (while reading header): (in file/uri /var/lib/clickhouse/user_files/test_02961_1752365118952639.csv): While executing CSVRowInputFormat: While executing File. (ZSTD_DECODER_FAILED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40746) (comment: 02961_output_format_compress_params.sh) (query 1, line 1) (in query: SELECT count() FROM file('test_02961_1752365118952639.csv', 'CSV', 'x UInt64', 'zstd') SETTINGS zstd_window_log_max = 29;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/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*&&, char const*&&, char const (&) [6], String&&) @ 0x000000000fb9d34b 4. /build/src/IO/ZstdInflatingReadBuffer.cpp:63: DB::ZstdInflatingReadBuffer::nextImpl() @ 0x000000000fb9d19b 5. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 6. /build/src/IO/PeekableReadBuffer.cpp:0: DB::PeekableReadBuffer::nextImpl() @ 0x000000000fb975d2 7. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 8. /build/src/IO/ReadBuffer.h:96: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x0000000016969657 9. /build/src/Processors/Formats/IRowInputFormat.cpp:97: DB::IRowInputFormat::read() @ 0x0000000016940612 10. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 11. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 12. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 15. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 16. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 17. /build/src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000015cae3aa 18. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 19. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 20. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 21. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 22. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 23. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 24. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 25. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:05:23.541935 [ 5998 ] {} TCPHandler: Code: 561. DB::Exception: ZSTD stream decoding failed: error 'Frame requires too much memory for decoding'; ZSTD version: 1.5.7: While reading from: /var/lib/clickhouse/user_files/test_02961_1752365118952639.csv: (while reading header): (in file/uri /var/lib/clickhouse/user_files/test_02961_1752365118952639.csv): While executing CSVRowInputFormat: While executing File. (ZSTD_DECODER_FAILED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/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*&&, char const*&&, char const (&) [6], String&&) @ 0x000000000fb9d34b 4. /build/src/IO/ZstdInflatingReadBuffer.cpp:63: DB::ZstdInflatingReadBuffer::nextImpl() @ 0x000000000fb9d19b 5. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 6. /build/src/IO/PeekableReadBuffer.cpp:0: DB::PeekableReadBuffer::nextImpl() @ 0x000000000fb975d2 7. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 8. /build/src/IO/ReadBuffer.h:96: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x0000000016969657 9. /build/src/Processors/Formats/IRowInputFormat.cpp:97: DB::IRowInputFormat::read() @ 0x0000000016940612 10. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 11. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 12. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 15. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 16. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 17. /build/src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000015cae3aa 18. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 19. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 20. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 21. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 22. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 23. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 24. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 25. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:05:24.153410 [ 6166 ] {dde72776-bfab-4fcd-a1d9-7ecea5afd7b9} executeQuery: Code: 632. DB::Exception: Unexpected data 'trash' after parsed DateTime64 value '1970-01-01 03:00:01.0000': (while reading the value of key x): (in file/uri /var/lib/clickhouse/user_files/test_i57376yt): While executing JSONCompactEachRowRowInputFormat: While executing File. (UNEXPECTED_DATA_AFTER_PARSED_VALUE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40768) (comment: 02118_deserialize_whole_text.sh) (query 1, line 1) (in query: SELECT * FROM file('test_i57376yt', 'JSONCompactStringsEachRow', 'x DateTime64(4)')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&) @ 0x00000000138567eb 4. /build/src/DataTypes/Serializations/ISerialization.cpp:499: DB::ISerialization::throwUnexpectedDataAfterParsedValue(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, String const&) const @ 0x0000000013ba210b 5. /build/src/DataTypes/Serializations/SerializationDateTime64.cpp:67: DB::SerializationDateTime64::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013bb4e4a 6. /build/src/DataTypes/Serializations/SerializationNullable.cpp:597: void DB::deserializeWholeTextImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x0000000013bf5ed4 7. /build/src/DataTypes/Serializations/SerializationNullable.cpp:622: DB::SerializationNullable::deserializeNullAsDefaultOrNestedWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000013bf478b 8. /build/src/Formats/JSONUtils.cpp:286: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x0000000016888f7d 9. /build/src/Processors/Formats/Impl/JSONCompactEachRowRowInputFormat.cpp:132: DB::JSONCompactEachRowFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000169e9eac 10. /build/src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001696565c 11. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016940972 12. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 13. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 14. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 18. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 19. /build/src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000015cae3aa 20. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 21. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 22. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 23. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 24. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 25. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:05:24.273565 [ 6166 ] {} TCPHandler: Code: 632. DB::Exception: Unexpected data 'trash' after parsed DateTime64 value '1970-01-01 03:00:01.0000': (while reading the value of key x): (in file/uri /var/lib/clickhouse/user_files/test_i57376yt): While executing JSONCompactEachRowRowInputFormat: While executing File. (UNEXPECTED_DATA_AFTER_PARSED_VALUE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&) @ 0x00000000138567eb 4. /build/src/DataTypes/Serializations/ISerialization.cpp:499: DB::ISerialization::throwUnexpectedDataAfterParsedValue(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, String const&) const @ 0x0000000013ba210b 5. /build/src/DataTypes/Serializations/SerializationDateTime64.cpp:67: DB::SerializationDateTime64::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013bb4e4a 6. /build/src/DataTypes/Serializations/SerializationNullable.cpp:597: void DB::deserializeWholeTextImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x0000000013bf5ed4 7. /build/src/DataTypes/Serializations/SerializationNullable.cpp:622: DB::SerializationNullable::deserializeNullAsDefaultOrNestedWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000013bf478b 8. /build/src/Formats/JSONUtils.cpp:286: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x0000000016888f7d 9. /build/src/Processors/Formats/Impl/JSONCompactEachRowRowInputFormat.cpp:132: DB::JSONCompactEachRowFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000169e9eac 10. /build/src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001696565c 11. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016940972 12. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 13. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 14. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 18. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 19. /build/src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000015cae3aa 20. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 21. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 22. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 23. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 24. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 25. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:05:24.620987 [ 6532 ] {3d2cb224-3d1d-4451-8dc4-bfb74ba3a547} 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]:40808) (comment: 02267_join_dup_columns_issue36199.sql) (query 1, line 1) (in query: SET enable_analyzer = 0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:05:24.649301 [ 6532 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:05:25.021356 [ 4269 ] {} 1851a938-6eec-4d9c-802e-a400081f71ea::all_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://933e750fc1f6:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_gqywdoo2%2Freplicas%2Fmaster&part=all_0_0_0_1&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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000fded159 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000fdecf62 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000fdecdb7 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000011747864 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x00000000117479b5 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000117481f9 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001174a27d 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001174592b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000117492ab 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 13. /build/src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000011747352 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000001173ed20 15. /build/src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000161362ae 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015eba47e 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015df873d 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015de95eb 19. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:178: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x00000000164af25c 20. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:208: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x00000000164ae329 21. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x00000000164acf56 22. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 23. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 25. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:25.025685 [ 4269 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1851a938-6eec-4d9c-802e-a400081f71ea::all_0_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://933e750fc1f6:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_gqywdoo2%2Freplicas%2Fmaster&part=all_0_0_0_1&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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000fded159 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000fdecf62 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000fdecdb7 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000011747864 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x00000000117479b5 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000117481f9 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001174a27d 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001174592b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000117492ab 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 13. /build/src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000011747352 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000001173ed20 15. /build/src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000161362ae 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015eba47e 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015df873d 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015de95eb 19. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:178: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x00000000164af25c 20. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:208: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x00000000164ae329 21. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x00000000164acf56 22. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 23. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 25. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:25.149678 [ 5121 ] {cdb90578-6055-4845-94a2-242028e267e9} executeQuery: Code: 632. DB::Exception: Unexpected data 'trash' after parsed Number value '42': (while reading the value of key x): (in file/uri /var/lib/clickhouse/user_files/test_i57376yt): While executing JSONCompactEachRowRowInputFormat: While executing File. (UNEXPECTED_DATA_AFTER_PARSED_VALUE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40812) (comment: 02118_deserialize_whole_text.sh) (query 1, line 1) (in query: SELECT * FROM file('test_i57376yt', 'JSONCompactStringsEachRow', 'x UInt32')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&) @ 0x00000000138567eb 4. /build/src/DataTypes/Serializations/ISerialization.cpp:499: DB::ISerialization::throwUnexpectedDataAfterParsedValue(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, String const&) const @ 0x0000000013ba210b 5. /build/src/DataTypes/Serializations/SerializationNumber.cpp:37: DB::SerializationNumber::deserializeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x0000000013bfb438 6. /build/src/DataTypes/Serializations/SerializationNullable.cpp:597: void DB::deserializeWholeTextImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x0000000013bf5ed4 7. /build/src/DataTypes/Serializations/SerializationNullable.cpp:622: DB::SerializationNullable::deserializeNullAsDefaultOrNestedWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000013bf478b 8. /build/src/Formats/JSONUtils.cpp:286: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x0000000016888f7d 9. /build/src/Processors/Formats/Impl/JSONCompactEachRowRowInputFormat.cpp:132: DB::JSONCompactEachRowFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000169e9eac 10. /build/src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001696565c 11. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016940972 12. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 13. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 14. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 18. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 19. /build/src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000015cae3aa 20. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 21. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 22. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 23. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 24. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 25. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:05:25.222368 [ 5121 ] {} TCPHandler: Code: 632. DB::Exception: Unexpected data 'trash' after parsed Number value '42': (while reading the value of key x): (in file/uri /var/lib/clickhouse/user_files/test_i57376yt): While executing JSONCompactEachRowRowInputFormat: While executing File. (UNEXPECTED_DATA_AFTER_PARSED_VALUE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&) @ 0x00000000138567eb 4. /build/src/DataTypes/Serializations/ISerialization.cpp:499: DB::ISerialization::throwUnexpectedDataAfterParsedValue(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, String const&) const @ 0x0000000013ba210b 5. /build/src/DataTypes/Serializations/SerializationNumber.cpp:37: DB::SerializationNumber::deserializeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x0000000013bfb438 6. /build/src/DataTypes/Serializations/SerializationNullable.cpp:597: void DB::deserializeWholeTextImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x0000000013bf5ed4 7. /build/src/DataTypes/Serializations/SerializationNullable.cpp:622: DB::SerializationNullable::deserializeNullAsDefaultOrNestedWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000013bf478b 8. /build/src/Formats/JSONUtils.cpp:286: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x0000000016888f7d 9. /build/src/Processors/Formats/Impl/JSONCompactEachRowRowInputFormat.cpp:132: DB::JSONCompactEachRowFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000169e9eac 10. /build/src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001696565c 11. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016940972 12. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 13. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 14. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 18. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 19. /build/src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000015cae3aa 20. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 21. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 22. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 23. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 24. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 25. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:05:25.429719 [ 4273 ] {} 1851a938-6eec-4d9c-802e-a400081f71ea::all_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://933e750fc1f6:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_gqywdoo2%2Freplicas%2Fmaster&part=all_0_0_0_1&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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000fded159 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000fdecf62 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000fdecdb7 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000011747864 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x00000000117479b5 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000117481f9 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001174a27d 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001174592b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000117492ab 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 13. /build/src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000011747352 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000001173ed20 15. /build/src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000161362ae 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015eba47e 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015df873d 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015de95eb 19. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:178: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x00000000164af25c 20. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:208: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x00000000164ae329 21. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x00000000164acf56 22. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 23. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 25. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:25.435548 [ 4273 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1851a938-6eec-4d9c-802e-a400081f71ea::all_0_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://933e750fc1f6:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_gqywdoo2%2Freplicas%2Fmaster&part=all_0_0_0_1&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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000fded159 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000fdecf62 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000fdecdb7 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000011747864 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x00000000117479b5 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000117481f9 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001174a27d 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001174592b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000117492ab 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 13. /build/src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000011747352 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000001173ed20 15. /build/src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000161362ae 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015eba47e 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015df873d 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015de95eb 19. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:178: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x00000000164af25c 20. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:208: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x00000000164ae329 21. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x00000000164acf56 22. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 23. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 25. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:25.762874 [ 4290 ] {} 1851a938-6eec-4d9c-802e-a400081f71ea::all_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://933e750fc1f6:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_gqywdoo2%2Freplicas%2Fmaster&part=all_0_0_0_1&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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000fded159 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000fdecf62 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000fdecdb7 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000011747864 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x00000000117479b5 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000117481f9 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001174a27d 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001174592b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000117492ab 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 13. /build/src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000011747352 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000001173ed20 15. /build/src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000161362ae 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015eba47e 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015df873d 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015de95eb 19. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:178: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x00000000164af25c 20. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:208: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x00000000164ae329 21. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x00000000164acf56 22. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 23. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 25. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:25.766435 [ 4290 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1851a938-6eec-4d9c-802e-a400081f71ea::all_0_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://933e750fc1f6:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_gqywdoo2%2Freplicas%2Fmaster&part=all_0_0_0_1&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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000fded159 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000fdecf62 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000fdecdb7 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000011747864 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x00000000117479b5 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000117481f9 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001174a27d 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001174592b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000117492ab 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 13. /build/src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000011747352 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000001173ed20 15. /build/src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000161362ae 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015eba47e 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015df873d 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015de95eb 19. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:178: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x00000000164af25c 20. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:208: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x00000000164ae329 21. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x00000000164acf56 22. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 23. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 25. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:26.025245 [ 3542 ] {99424228-6752-4654-b144-da40d7772e35} executeQuery: Code: 632. DB::Exception: Unexpected data 'trash' after parsed Decimal value '42.4242': (while reading the value of key x): (in file/uri /var/lib/clickhouse/user_files/test_i57376yt): While executing JSONCompactEachRowRowInputFormat: While executing File. (UNEXPECTED_DATA_AFTER_PARSED_VALUE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40842) (comment: 02118_deserialize_whole_text.sh) (query 1, line 1) (in query: SELECT * FROM file('test_i57376yt', 'JSONCompactStringsEachRow', 'x Decimal32(4)')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&) @ 0x00000000138567eb 4. /build/src/DataTypes/Serializations/ISerialization.cpp:499: DB::ISerialization::throwUnexpectedDataAfterParsedValue(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, String const&) const @ 0x0000000013ba210b 5. /build/src/DataTypes/Serializations/SerializationDecimal.cpp:67: DB::SerializationDecimal>::deserializeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x0000000013bb6286 6. /build/src/DataTypes/Serializations/SerializationNullable.cpp:597: void DB::deserializeWholeTextImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x0000000013bf5ed4 7. /build/src/DataTypes/Serializations/SerializationNullable.cpp:622: DB::SerializationNullable::deserializeNullAsDefaultOrNestedWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000013bf478b 8. /build/src/Formats/JSONUtils.cpp:286: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x0000000016888f7d 9. /build/src/Processors/Formats/Impl/JSONCompactEachRowRowInputFormat.cpp:132: DB::JSONCompactEachRowFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000169e9eac 10. /build/src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001696565c 11. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016940972 12. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 13. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 14. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 18. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 19. /build/src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000015cae3aa 20. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 21. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 22. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 23. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 24. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 25. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:05:26.103591 [ 3542 ] {} TCPHandler: Code: 632. DB::Exception: Unexpected data 'trash' after parsed Decimal value '42.4242': (while reading the value of key x): (in file/uri /var/lib/clickhouse/user_files/test_i57376yt): While executing JSONCompactEachRowRowInputFormat: While executing File. (UNEXPECTED_DATA_AFTER_PARSED_VALUE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&) @ 0x00000000138567eb 4. /build/src/DataTypes/Serializations/ISerialization.cpp:499: DB::ISerialization::throwUnexpectedDataAfterParsedValue(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, String const&) const @ 0x0000000013ba210b 5. /build/src/DataTypes/Serializations/SerializationDecimal.cpp:67: DB::SerializationDecimal>::deserializeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x0000000013bb6286 6. /build/src/DataTypes/Serializations/SerializationNullable.cpp:597: void DB::deserializeWholeTextImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x0000000013bf5ed4 7. /build/src/DataTypes/Serializations/SerializationNullable.cpp:622: DB::SerializationNullable::deserializeNullAsDefaultOrNestedWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000013bf478b 8. /build/src/Formats/JSONUtils.cpp:286: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x0000000016888f7d 9. /build/src/Processors/Formats/Impl/JSONCompactEachRowRowInputFormat.cpp:132: DB::JSONCompactEachRowFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000169e9eac 10. /build/src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001696565c 11. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016940972 12. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 13. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 14. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 18. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 19. /build/src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000015cae3aa 20. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 21. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 22. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 23. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 24. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 25. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:05:26.541078 [ 4273 ] {} 1851a938-6eec-4d9c-802e-a400081f71ea::all_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://933e750fc1f6:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_gqywdoo2%2Freplicas%2Fmaster&part=all_0_0_0_1&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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000fded159 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000fdecf62 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000fdecdb7 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000011747864 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x00000000117479b5 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000117481f9 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001174a27d 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001174592b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000117492ab 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 13. /build/src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000011747352 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000001173ed20 15. /build/src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000161362ae 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015eba47e 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015df873d 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015de95eb 19. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:178: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x00000000164af25c 20. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:208: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x00000000164ae329 21. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x00000000164acf56 22. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 23. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 25. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:26.549470 [ 4273 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1851a938-6eec-4d9c-802e-a400081f71ea::all_0_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://933e750fc1f6:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_gqywdoo2%2Freplicas%2Fmaster&part=all_0_0_0_1&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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000fded159 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000fdecf62 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000fdecdb7 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000011747864 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x00000000117479b5 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000117481f9 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001174a27d 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001174592b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000117492ab 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 13. /build/src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000011747352 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000001173ed20 15. /build/src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000161362ae 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015eba47e 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015df873d 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015de95eb 19. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:178: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x00000000164af25c 20. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:208: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x00000000164ae329 21. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x00000000164acf56 22. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 23. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 25. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:27.137764 [ 3542 ] {f691347b-c1ef-4c4b-b23e-0ab40ac193a5} executeQuery: Code: 632. DB::Exception: Unexpected data 'trash' after parsed IPv4 value '255.255.255.255': (while reading the value of key x): (in file/uri /var/lib/clickhouse/user_files/test_i57376yt): While executing JSONCompactEachRowRowInputFormat: While executing File. (UNEXPECTED_DATA_AFTER_PARSED_VALUE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40864) (comment: 02118_deserialize_whole_text.sh) (query 1, line 1) (in query: SELECT * FROM file('test_i57376yt', 'JSONCompactStringsEachRow', 'x IPv4')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&) @ 0x00000000138567eb 4. /build/src/DataTypes/Serializations/ISerialization.cpp:499: DB::ISerialization::throwUnexpectedDataAfterParsedValue(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, String const&) const @ 0x0000000013ba210b 5. /build/src/DataTypes/Serializations/SerializationIPv4andIPv6.cpp:23: DB::SerializationIP::deserializeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x0000000013bd2c65 6. /build/src/DataTypes/Serializations/SerializationNullable.cpp:597: void DB::deserializeWholeTextImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x0000000013bf5ed4 7. /build/src/DataTypes/Serializations/SerializationNullable.cpp:622: DB::SerializationNullable::deserializeNullAsDefaultOrNestedWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000013bf478b 8. /build/src/Formats/JSONUtils.cpp:286: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x0000000016888f7d 9. /build/src/Processors/Formats/Impl/JSONCompactEachRowRowInputFormat.cpp:132: DB::JSONCompactEachRowFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000169e9eac 10. /build/src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001696565c 11. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016940972 12. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 13. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 14. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 18. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 19. /build/src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000015cae3aa 20. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 21. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 22. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 23. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 24. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 25. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:05:27.267896 [ 3542 ] {} TCPHandler: Code: 632. DB::Exception: Unexpected data 'trash' after parsed IPv4 value '255.255.255.255': (while reading the value of key x): (in file/uri /var/lib/clickhouse/user_files/test_i57376yt): While executing JSONCompactEachRowRowInputFormat: While executing File. (UNEXPECTED_DATA_AFTER_PARSED_VALUE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&) @ 0x00000000138567eb 4. /build/src/DataTypes/Serializations/ISerialization.cpp:499: DB::ISerialization::throwUnexpectedDataAfterParsedValue(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, String const&) const @ 0x0000000013ba210b 5. /build/src/DataTypes/Serializations/SerializationIPv4andIPv6.cpp:23: DB::SerializationIP::deserializeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x0000000013bd2c65 6. /build/src/DataTypes/Serializations/SerializationNullable.cpp:597: void DB::deserializeWholeTextImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x0000000013bf5ed4 7. /build/src/DataTypes/Serializations/SerializationNullable.cpp:622: DB::SerializationNullable::deserializeNullAsDefaultOrNestedWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000013bf478b 8. /build/src/Formats/JSONUtils.cpp:286: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x0000000016888f7d 9. /build/src/Processors/Formats/Impl/JSONCompactEachRowRowInputFormat.cpp:132: DB::JSONCompactEachRowFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000169e9eac 10. /build/src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001696565c 11. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016940972 12. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 13. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 14. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 18. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 19. /build/src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000015cae3aa 20. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 21. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 22. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 23. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 24. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 25. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:05:27.498596 [ 6168 ] {e98cfa24-ac8b-4a4b-9a89-a56c0d16e388} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=3): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40686) (query 8, line 21) (in query: select count() from system.query_log where query like 'select \'01547_query_log_current_database%' and current_database = currentDatabase() and event_date >= yesterday();), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x00000000163993d1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016396620 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001639641f 10. /build/src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000163b2bd7 11. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x00000000162ea22d 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x00000000162e6974 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x00000000163d9ded 14. /build/src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x0000000016d7885f 15. /build/src/Storages/MergeTree/MergeTreeReadPool.cpp:159: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x0000000016d96c0a 16. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5520 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 18. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 22. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:05:27.653238 [ 6168 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=3): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x00000000163993d1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016396620 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001639641f 10. /build/src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000163b2bd7 11. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x00000000162ea22d 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x00000000162e6974 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x00000000163d9ded 14. /build/src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x0000000016d7885f 15. /build/src/Storages/MergeTree/MergeTreeReadPool.cpp:159: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x0000000016d96c0a 16. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5520 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 18. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 22. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:05:27.821793 [ 4281 ] {} 1851a938-6eec-4d9c-802e-a400081f71ea::all_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://933e750fc1f6:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_gqywdoo2%2Freplicas%2Fmaster&part=all_0_0_0_1&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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000fded159 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000fdecf62 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000fdecdb7 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000011747864 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x00000000117479b5 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000117481f9 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001174a27d 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001174592b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000117492ab 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 13. /build/src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000011747352 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000001173ed20 15. /build/src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000161362ae 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015eba47e 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015df873d 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015de95eb 19. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:178: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x00000000164af25c 20. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:208: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x00000000164ae329 21. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x00000000164acf56 22. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 23. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 25. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:27.824304 [ 4281 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1851a938-6eec-4d9c-802e-a400081f71ea::all_0_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://933e750fc1f6:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_gqywdoo2%2Freplicas%2Fmaster&part=all_0_0_0_1&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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000fded159 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000fdecf62 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000fdecdb7 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000011747864 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x00000000117479b5 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000117481f9 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001174a27d 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001174592b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000117492ab 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 13. /build/src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000011747352 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000001173ed20 15. /build/src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000161362ae 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015eba47e 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015df873d 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015de95eb 19. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:178: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x00000000164af25c 20. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:208: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x00000000164ae329 21. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x00000000164acf56 22. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 23. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 25. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:28.257199 [ 3542 ] {78ee2eec-20ca-4290-8a11-c61d8af5cbf2} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected '\n' before: 'trash\n': (at row 1) : Row 1: Column 0, name: x, type: IPv4, parsed text: "255.255.255.255" ERROR: garbage after IPv4: "trash" : (in file/uri /var/lib/clickhouse/user_files/test_i57376yt): While executing TabSeparatedRowInputFormat: While executing File. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40882) (comment: 02118_deserialize_whole_text.sh) (query 1, line 1) (in query: SELECT * FROM file('test_i57376yt', 'TSV', 'x IPv4')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/IO/ReadHelpers.cpp:95: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000000fb7e1e9 5. /build/src/IO/ReadHelpers.h:204: DB::TabSeparatedFormatReader::skipRowEndDelimiter() @ 0x0000000016adf525 6. /build/src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:315: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000169689c4 7. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016940972 8. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 9. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 10. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 11. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 12. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 13. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 14. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 15. /build/src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000015cae3aa 16. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 17. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 18. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 19. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 20. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 21. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 23. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 25. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:05:28.315515 [ 3542 ] {} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected '\n' before: 'trash\n': (at row 1) : Row 1: Column 0, name: x, type: IPv4, parsed text: "255.255.255.255" ERROR: garbage after IPv4: "trash" : (in file/uri /var/lib/clickhouse/user_files/test_i57376yt): While executing TabSeparatedRowInputFormat: While executing File. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/IO/ReadHelpers.cpp:95: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000000fb7e1e9 5. /build/src/IO/ReadHelpers.h:204: DB::TabSeparatedFormatReader::skipRowEndDelimiter() @ 0x0000000016adf525 6. /build/src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:315: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000169689c4 7. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016940972 8. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 9. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 10. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 11. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 12. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 13. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 14. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 15. /build/src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000015cae3aa 16. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 17. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 18. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 19. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 20. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 21. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 23. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 25. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:05:28.618605 [ 4274 ] {} 1851a938-6eec-4d9c-802e-a400081f71ea::all_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://933e750fc1f6:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_gqywdoo2%2Freplicas%2Fmaster&part=all_0_0_0_1&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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000fded159 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000fdecf62 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000fdecdb7 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000011747864 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x00000000117479b5 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000117481f9 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001174a27d 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001174592b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000117492ab 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 13. /build/src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000011747352 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000001173ed20 15. /build/src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000161362ae 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015eba47e 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015df873d 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015de95eb 19. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:178: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x00000000164af25c 20. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:208: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x00000000164ae329 21. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x00000000164acf56 22. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 23. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 25. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:28.622431 [ 4274 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1851a938-6eec-4d9c-802e-a400081f71ea::all_0_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://933e750fc1f6:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_gqywdoo2%2Freplicas%2Fmaster&part=all_0_0_0_1&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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000fded159 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000fdecf62 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000fdecdb7 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000011747864 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x00000000117479b5 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000117481f9 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001174a27d 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001174592b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000117492ab 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 13. /build/src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000011747352 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000001173ed20 15. /build/src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000161362ae 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015eba47e 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015df873d 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015de95eb 19. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:178: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x00000000164af25c 20. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:208: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x00000000164ae329 21. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x00000000164acf56 22. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 23. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 25. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:29.260802 [ 4282 ] {f939ca10-ce35-42da-9773-940a0d8c61fe::202507_1_71_14} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x00000000163993d1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016396620 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001639641f 10. /build/src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000163b2bd7 11. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x00000000162ea22d 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x00000000162e6974 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x00000000163d9d66 14. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:159: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::Block, DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr, std::shared_ptr, std::optional, bool, bool) @ 0x00000000163d3337 15. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:se190107] const&, std::shared_ptr, std::optional, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x00000000163d9212 16. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x00000000163d553a 17. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:383: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000163d7ceb 18. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016cf6870 19. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 20. /build/src/Storages/MergeTree/MergeTask.cpp:1910: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() const @ 0x00000000161f8487 21. /build/src/Storages/MergeTree/MergeTask.cpp:567: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000161f2613 22. /build/src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000161f9939 23. /build/src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000161ffd8a 24. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000016592b05 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 26. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 28. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 30. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 31. ? @ 0x00007f7210eb6ac3 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:29.287303 [ 6637 ] {db048857-9730-4600-ac0a-220bf1a58ed8} executeQuery: Code: 117. DB::Exception: Expected end of line: (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_i57376yt): While executing CSVRowInputFormat: While executing File. (INCORRECT_DATA) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40982) (comment: 02118_deserialize_whole_text.sh) (query 1, line 1) (in query: SELECT * FROM file('test_i57376yt', 'CSV', 'x IPv4')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Processors/Formats/Impl/CSVRowInputFormat.cpp:208: DB::skipEndOfLine(DB::ReadBuffer&, bool) @ 0x00000000169992fc 5. /build/src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:315: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001696b9bb 6. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016940972 7. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 8. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 9. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 10. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 11. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 12. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 13. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 14. /build/src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000015cae3aa 15. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 16. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 17. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 18. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 19. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 20. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 2025.07.13 02:05:29.291309 [ 4282 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {f939ca10-ce35-42da-9773-940a0d8c61fe::202507_1_71_14}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x00000000163993d1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016396620 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001639641f 10. /build/src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000163b2bd7 11. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x00000000162ea22d 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x00000000162e6974 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x00000000163d9d66 14. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:159: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::Block, DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr, std::shared_ptr, std::optional, bool, bool) @ 0x00000000163d3337 15. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:se190107] const&, std::shared_ptr, std::optional, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x00000000163d9212 16. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x00000000163d553a 17. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:383: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000163d7ceb 18. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016cf6870 19. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 20. /build/src/Storages/MergeTree/MergeTask.cpp:1910: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() const @ 0x00000000161f8487 21. /build/src/Storages/MergeTree/MergeTask.cpp:567: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000161f2613 22. /build/src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000161f9939 23. /build/src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000161ffd8a 24. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000016592b05 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 26. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 28. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 30. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 31. ? @ 0x00007f7210eb6ac3 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:29.366079 [ 4267 ] {} 1851a938-6eec-4d9c-802e-a400081f71ea::all_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://933e750fc1f6:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_gqywdoo2%2Freplicas%2Fmaster&part=all_0_0_0_1&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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000fded159 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000fdecf62 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000fdecdb7 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000011747864 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x00000000117479b5 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000117481f9 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001174a27d 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001174592b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000117492ab 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 13. /build/src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000011747352 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000001173ed20 15. /build/src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000161362ae 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015eba47e 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015df873d 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015de95eb 19. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:178: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x00000000164af25c 20. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:208: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x00000000164ae329 21. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x00000000164acf56 22. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 23. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 25. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:29.373471 [ 6637 ] {} TCPHandler: Code: 117. DB::Exception: Expected end of line: (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_i57376yt): While executing CSVRowInputFormat: While executing File. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Processors/Formats/Impl/CSVRowInputFormat.cpp:208: DB::skipEndOfLine(DB::ReadBuffer&, bool) @ 0x00000000169992fc 5. /build/src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:315: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001696b9bb 6. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016940972 7. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 8. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 9. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 10. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 11. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 12. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 13. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 14. /build/src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000015cae3aa 15. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 16. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 17. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 18. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 19. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 20. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:05:29.374128 [ 4267 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1851a938-6eec-4d9c-802e-a400081f71ea::all_0_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://933e750fc1f6:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_gqywdoo2%2Freplicas%2Fmaster&part=all_0_0_0_1&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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000fded159 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000fdecf62 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000fdecdb7 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000011747864 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x00000000117479b5 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000117481f9 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001174a27d 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001174592b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000117492ab 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 13. /build/src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000011747352 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000001173ed20 15. /build/src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000161362ae 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015eba47e 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015df873d 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015de95eb 19. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:178: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x00000000164af25c 20. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:208: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x00000000164ae329 21. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x00000000164acf56 22. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 23. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 25. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:30.173094 [ 4275 ] {} 1851a938-6eec-4d9c-802e-a400081f71ea::all_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://933e750fc1f6:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_gqywdoo2%2Freplicas%2Fmaster&part=all_0_0_0_1&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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000fded159 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000fdecf62 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000fdecdb7 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000011747864 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x00000000117479b5 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000117481f9 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001174a27d 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001174592b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000117492ab 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 13. /build/src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000011747352 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000001173ed20 15. /build/src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000161362ae 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015eba47e 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015df873d 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015de95eb 19. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:178: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x00000000164af25c 20. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:208: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x00000000164ae329 21. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x00000000164acf56 22. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 23. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 25. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:30.176729 [ 4275 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1851a938-6eec-4d9c-802e-a400081f71ea::all_0_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://933e750fc1f6:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_gqywdoo2%2Freplicas%2Fmaster&part=all_0_0_0_1&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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000fded159 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000fdecf62 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000fdecdb7 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000011747864 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x00000000117479b5 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000117481f9 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001174a27d 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001174592b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000117492ab 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 13. /build/src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000011747352 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000001173ed20 15. /build/src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000161362ae 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015eba47e 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015df873d 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015de95eb 19. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:178: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x00000000164af25c 20. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:208: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x00000000164ae329 21. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x00000000164acf56 22. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 23. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 25. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:30.241034 [ 3542 ] {e1acd1c0-1335-41e5-a370-3809fd7aac84} executeQuery: Code: 632. DB::Exception: Unexpected data 'trash"] ' after parsed IPv4 value '255.255.255.255': (while reading the value of key x): (in file/uri /var/lib/clickhouse/user_files/test_i57376yt): While executing JSONCompactEachRowRowInputFormat: While executing File. (UNEXPECTED_DATA_AFTER_PARSED_VALUE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60282) (comment: 02118_deserialize_whole_text.sh) (query 1, line 1) (in query: SELECT * FROM file('test_i57376yt', 'JSONCompactEachRow', 'x IPv4')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&) @ 0x00000000138567eb 4. /build/src/DataTypes/Serializations/ISerialization.cpp:499: DB::ISerialization::throwUnexpectedDataAfterParsedValue(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, String const&) const @ 0x0000000013ba210b 5. /build/src/DataTypes/Serializations/SerializationIPv4andIPv6.cpp:84: DB::SerializationIP::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013bd3371 6. /build/src/DataTypes/Serializations/SerializationNullable.cpp:841: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000013bf4fab 7. /build/src/Formats/JSONUtils.cpp:295: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x0000000016888f98 8. /build/src/Processors/Formats/Impl/JSONCompactEachRowRowInputFormat.cpp:132: DB::JSONCompactEachRowFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000169e9eac 9. /build/src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001696565c 10. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016940972 11. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 12. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 13. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 16. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 17. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 18. /build/src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000015cae3aa 19. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 20. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 21. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 22. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 23. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 24. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 28. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:05:30.304473 [ 3542 ] {} TCPHandler: Code: 632. DB::Exception: Unexpected data 'trash"] ' after parsed IPv4 value '255.255.255.255': (while reading the value of key x): (in file/uri /var/lib/clickhouse/user_files/test_i57376yt): While executing JSONCompactEachRowRowInputFormat: While executing File. (UNEXPECTED_DATA_AFTER_PARSED_VALUE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&) @ 0x00000000138567eb 4. /build/src/DataTypes/Serializations/ISerialization.cpp:499: DB::ISerialization::throwUnexpectedDataAfterParsedValue(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, String const&) const @ 0x0000000013ba210b 5. /build/src/DataTypes/Serializations/SerializationIPv4andIPv6.cpp:84: DB::SerializationIP::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013bd3371 6. /build/src/DataTypes/Serializations/SerializationNullable.cpp:841: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000013bf4fab 7. /build/src/Formats/JSONUtils.cpp:295: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x0000000016888f98 8. /build/src/Processors/Formats/Impl/JSONCompactEachRowRowInputFormat.cpp:132: DB::JSONCompactEachRowFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000169e9eac 9. /build/src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001696565c 10. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016940972 11. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 12. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 13. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 16. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 17. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 18. /build/src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000015cae3aa 19. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 20. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 21. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 22. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 23. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 24. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 28. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:05:30.792964 [ 4290 ] {} 1851a938-6eec-4d9c-802e-a400081f71ea::all_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://933e750fc1f6:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_gqywdoo2%2Freplicas%2Fmaster&part=all_0_0_0_1&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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000fded159 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000fdecf62 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000fdecdb7 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000011747864 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x00000000117479b5 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000117481f9 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001174a27d 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001174592b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000117492ab 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 13. /build/src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000011747352 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000001173ed20 15. /build/src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000161362ae 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015eba47e 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015df873d 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015de95eb 19. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:178: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x00000000164af25c 20. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:208: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x00000000164ae329 21. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x00000000164acf56 22. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 23. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 25. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:30.802944 [ 4290 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1851a938-6eec-4d9c-802e-a400081f71ea::all_0_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://933e750fc1f6:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_gqywdoo2%2Freplicas%2Fmaster&part=all_0_0_0_1&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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000fded159 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000fdecf62 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000fdecdb7 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000011747864 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x00000000117479b5 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000117481f9 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001174a27d 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001174592b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000117492ab 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 13. /build/src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000011747352 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000001173ed20 15. /build/src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000161362ae 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015eba47e 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015df873d 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015de95eb 19. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:178: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x00000000164af25c 20. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:208: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x00000000164ae329 21. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x00000000164acf56 22. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 23. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 25. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:31.182731 [ 6166 ] {0e24c164-16ab-4776-b705-eceb920ec77d} executeQuery: Code: 632. DB::Exception: Unexpected data 'b1trash' after parsed IPv6 value '::ffff:192.168.100.228': (while reading the value of key x): (in file/uri /var/lib/clickhouse/user_files/test_i57376yt): While executing JSONCompactEachRowRowInputFormat: While executing File. (UNEXPECTED_DATA_AFTER_PARSED_VALUE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60308) (comment: 02118_deserialize_whole_text.sh) (query 1, line 1) (in query: SELECT * FROM file('test_i57376yt', 'JSONCompactStringsEachRow', 'x IPv6')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&) @ 0x00000000138567eb 4. /build/src/DataTypes/Serializations/ISerialization.cpp:499: DB::ISerialization::throwUnexpectedDataAfterParsedValue(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, String const&) const @ 0x0000000013ba210b 5. /build/src/DataTypes/Serializations/SerializationIPv4andIPv6.cpp:23: DB::SerializationIP::deserializeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x0000000013bd3f85 6. /build/src/DataTypes/Serializations/SerializationNullable.cpp:597: void DB::deserializeWholeTextImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x0000000013bf5ed4 7. /build/src/DataTypes/Serializations/SerializationNullable.cpp:622: DB::SerializationNullable::deserializeNullAsDefaultOrNestedWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000013bf478b 8. /build/src/Formats/JSONUtils.cpp:286: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x0000000016888f7d 9. /build/src/Processors/Formats/Impl/JSONCompactEachRowRowInputFormat.cpp:132: DB::JSONCompactEachRowFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000169e9eac 10. /build/src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001696565c 11. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016940972 12. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 13. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 14. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 18. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 19. /build/src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000015cae3aa 20. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 21. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 22. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 23. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 24. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 25. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:05:31.324994 [ 6166 ] {} TCPHandler: Code: 632. DB::Exception: Unexpected data 'b1trash' after parsed IPv6 value '::ffff:192.168.100.228': (while reading the value of key x): (in file/uri /var/lib/clickhouse/user_files/test_i57376yt): While executing JSONCompactEachRowRowInputFormat: While executing File. (UNEXPECTED_DATA_AFTER_PARSED_VALUE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&) @ 0x00000000138567eb 4. /build/src/DataTypes/Serializations/ISerialization.cpp:499: DB::ISerialization::throwUnexpectedDataAfterParsedValue(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, String const&) const @ 0x0000000013ba210b 5. /build/src/DataTypes/Serializations/SerializationIPv4andIPv6.cpp:23: DB::SerializationIP::deserializeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x0000000013bd3f85 6. /build/src/DataTypes/Serializations/SerializationNullable.cpp:597: void DB::deserializeWholeTextImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x0000000013bf5ed4 7. /build/src/DataTypes/Serializations/SerializationNullable.cpp:622: DB::SerializationNullable::deserializeNullAsDefaultOrNestedWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000013bf478b 8. /build/src/Formats/JSONUtils.cpp:286: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x0000000016888f7d 9. /build/src/Processors/Formats/Impl/JSONCompactEachRowRowInputFormat.cpp:132: DB::JSONCompactEachRowFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000169e9eac 10. /build/src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001696565c 11. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016940972 12. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 13. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 14. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 18. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 19. /build/src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000015cae3aa 20. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 21. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 22. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 23. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 24. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 25. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:05:31.778229 [ 4269 ] {} 1851a938-6eec-4d9c-802e-a400081f71ea::all_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://933e750fc1f6:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_gqywdoo2%2Freplicas%2Fmaster&part=all_0_0_0_1&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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000fded159 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000fdecf62 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000fdecdb7 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000011747864 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x00000000117479b5 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000117481f9 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001174a27d 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001174592b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000117492ab 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 13. /build/src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000011747352 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000001173ed20 15. /build/src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000161362ae 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015eba47e 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015df873d 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015de95eb 19. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:178: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x00000000164af25c 20. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:208: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x00000000164ae329 21. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x00000000164acf56 22. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 23. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 25. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:31.785123 [ 4269 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1851a938-6eec-4d9c-802e-a400081f71ea::all_0_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://933e750fc1f6:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_gqywdoo2%2Freplicas%2Fmaster&part=all_0_0_0_1&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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000fded159 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000fdecf62 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000fdecdb7 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000011747864 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x00000000117479b5 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000117481f9 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001174a27d 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001174592b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000117492ab 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 13. /build/src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000011747352 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000001173ed20 15. /build/src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000161362ae 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015eba47e 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015df873d 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015de95eb 19. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:178: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x00000000164af25c 20. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:208: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x00000000164ae329 21. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x00000000164acf56 22. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 23. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 25. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:32.302486 [ 6166 ] {baaa7889-a7d9-406a-9f2c-ca27f3e32878} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=1). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60344) (comment: 02118_deserialize_whole_text.sh) (query 1, line 1) (in query: SELECT * FROM file('test_i57376yt', 'TSV', 'x IPv6')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 9. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:05:32.353910 [ 6166 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 9. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:05:32.730210 [ 4278 ] {} 1851a938-6eec-4d9c-802e-a400081f71ea::all_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://933e750fc1f6:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_gqywdoo2%2Freplicas%2Fmaster&part=all_0_0_0_1&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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000fded159 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000fdecf62 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000fdecdb7 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000011747864 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x00000000117479b5 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000117481f9 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001174a27d 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001174592b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000117492ab 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 13. /build/src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000011747352 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000001173ed20 15. /build/src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000161362ae 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015eba47e 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015df873d 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015de95eb 19. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:178: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x00000000164af25c 20. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:208: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x00000000164ae329 21. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x00000000164acf56 22. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 23. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 25. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:32.732556 [ 4278 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1851a938-6eec-4d9c-802e-a400081f71ea::all_0_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://933e750fc1f6:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_gqywdoo2%2Freplicas%2Fmaster&part=all_0_0_0_1&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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000fded159 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000fdecf62 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000fdecdb7 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000011747864 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x00000000117479b5 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000117481f9 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001174a27d 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001174592b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000117492ab 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 13. /build/src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000011747352 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000001173ed20 15. /build/src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000161362ae 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015eba47e 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015df873d 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015de95eb 19. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:178: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x00000000164af25c 20. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:208: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x00000000164ae329 21. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x00000000164acf56 22. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 23. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 25. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:33.083599 [ 6166 ] {6c8cc7ea-4b2b-4e05-9534-85c0a3943c97} executeQuery: Code: 117. DB::Exception: Expected end of line: (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_i57376yt): While executing CSVRowInputFormat: While executing File. (INCORRECT_DATA) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60346) (comment: 02118_deserialize_whole_text.sh) (query 1, line 1) (in query: SELECT * FROM file('test_i57376yt', 'CSV', 'x IPv6')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Processors/Formats/Impl/CSVRowInputFormat.cpp:208: DB::skipEndOfLine(DB::ReadBuffer&, bool) @ 0x00000000169992fc 5. /build/src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:315: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001696b9bb 6. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016940972 7. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 8. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 9. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 10. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 11. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 12. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 13. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 14. /build/src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000015cae3aa 15. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 16. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 17. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 18. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 19. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 20. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 2025.07.13 02:05:33.201148 [ 6166 ] {} TCPHandler: Code: 117. DB::Exception: Expected end of line: (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_i57376yt): While executing CSVRowInputFormat: While executing File. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Processors/Formats/Impl/CSVRowInputFormat.cpp:208: DB::skipEndOfLine(DB::ReadBuffer&, bool) @ 0x00000000169992fc 5. /build/src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:315: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001696b9bb 6. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016940972 7. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 8. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 9. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 10. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 11. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 12. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 13. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 14. /build/src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000015cae3aa 15. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 16. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 17. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 18. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 19. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 20. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:05:33.245420 [ 4278 ] {} 1851a938-6eec-4d9c-802e-a400081f71ea::all_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://933e750fc1f6:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_gqywdoo2%2Freplicas%2Fmaster&part=all_0_0_0_1&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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000fded159 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000fdecf62 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000fdecdb7 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000011747864 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x00000000117479b5 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000117481f9 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001174a27d 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001174592b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000117492ab 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 13. /build/src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000011747352 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000001173ed20 15. /build/src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000161362ae 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015eba47e 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015df873d 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015de95eb 19. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:178: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x00000000164af25c 20. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:208: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x00000000164ae329 21. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x00000000164acf56 22. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 23. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 25. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:33.248052 [ 4278 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1851a938-6eec-4d9c-802e-a400081f71ea::all_0_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://933e750fc1f6:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_gqywdoo2%2Freplicas%2Fmaster&part=all_0_0_0_1&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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000fded159 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000fdecf62 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000fdecdb7 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000011747864 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x00000000117479b5 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000117481f9 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001174a27d 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001174592b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000117492ab 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 13. /build/src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000011747352 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000001173ed20 15. /build/src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000161362ae 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015eba47e 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015df873d 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015de95eb 19. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:178: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x00000000164af25c 20. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:208: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x00000000164ae329 21. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x00000000164acf56 22. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 23. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 25. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:33.862737 [ 4290 ] {} 1851a938-6eec-4d9c-802e-a400081f71ea::all_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://933e750fc1f6:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_gqywdoo2%2Freplicas%2Fmaster&part=all_0_0_0_1&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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000fded159 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000fdecf62 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000fdecdb7 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000011747864 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x00000000117479b5 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000117481f9 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001174a27d 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001174592b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000117492ab 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 13. /build/src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000011747352 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000001173ed20 15. /build/src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000161362ae 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015eba47e 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015df873d 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015de95eb 19. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:178: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x00000000164af25c 20. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:208: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x00000000164ae329 21. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x00000000164acf56 22. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 23. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 25. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:33.890122 [ 4290 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1851a938-6eec-4d9c-802e-a400081f71ea::all_0_0_0_1}: Code: 86. DB::HTTPException: Received error from remote server http://933e750fc1f6:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftest_gqywdoo2%2Freplicas%2Fmaster&part=all_0_0_0_1&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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000fded159 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000fdecf62 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000fdecdb7 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000011747864 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x00000000117479b5 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000117481f9 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001174a27d 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001174592b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000117492ab 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 13. /build/src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000011747352 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000001173ed20 15. /build/src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000161362ae 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015eba47e 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015df873d 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015de95eb 19. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:178: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x00000000164af25c 20. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:208: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x00000000164ae329 21. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x00000000164acf56 22. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 23. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 25. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:34.311030 [ 3648 ] {} DNSResolver: Cannot resolve host (localhos), error 0: Host not found. 2025.07.13 02:05:34.309860 [ 6615 ] {9a1ab372-8bf7-4afb-8c93-93cc6eab549b} executeQuery: Code: 632. DB::Exception: Unexpected data 'b1trash"] ' after parsed IPv6 value '::ffff:192.168.100.228': (while reading the value of key x): (in file/uri /var/lib/clickhouse/user_files/test_i57376yt): While executing JSONCompactEachRowRowInputFormat: While executing File. (UNEXPECTED_DATA_AFTER_PARSED_VALUE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60382) (comment: 02118_deserialize_whole_text.sh) (query 1, line 1) (in query: SELECT * FROM file('test_i57376yt', 'JSONCompactEachRow', 'x IPv6')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&) @ 0x00000000138567eb 4. /build/src/DataTypes/Serializations/ISerialization.cpp:499: DB::ISerialization::throwUnexpectedDataAfterParsedValue(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, String const&) const @ 0x0000000013ba210b 5. /build/src/DataTypes/Serializations/SerializationIPv4andIPv6.cpp:84: DB::SerializationIP::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013bd4811 6. /build/src/DataTypes/Serializations/SerializationNullable.cpp:841: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000013bf4fab 7. /build/src/Formats/JSONUtils.cpp:295: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x0000000016888f98 8. /build/src/Processors/Formats/Impl/JSONCompactEachRowRowInputFormat.cpp:132: DB::JSONCompactEachRowFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000169e9eac 9. /build/src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001696565c 10. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016940972 11. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 12. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 13. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 16. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 17. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 18. /build/src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000015cae3aa 19. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 20. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 21. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 22. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 23. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 24. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 28. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:05:34.555977 [ 6615 ] {} TCPHandler: Code: 632. DB::Exception: Unexpected data 'b1trash"] ' after parsed IPv6 value '::ffff:192.168.100.228': (while reading the value of key x): (in file/uri /var/lib/clickhouse/user_files/test_i57376yt): While executing JSONCompactEachRowRowInputFormat: While executing File. (UNEXPECTED_DATA_AFTER_PARSED_VALUE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&) @ 0x00000000138567eb 4. /build/src/DataTypes/Serializations/ISerialization.cpp:499: DB::ISerialization::throwUnexpectedDataAfterParsedValue(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, String const&) const @ 0x0000000013ba210b 5. /build/src/DataTypes/Serializations/SerializationIPv4andIPv6.cpp:84: DB::SerializationIP::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013bd4811 6. /build/src/DataTypes/Serializations/SerializationNullable.cpp:841: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000013bf4fab 7. /build/src/Formats/JSONUtils.cpp:295: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x0000000016888f98 8. /build/src/Processors/Formats/Impl/JSONCompactEachRowRowInputFormat.cpp:132: DB::JSONCompactEachRowFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000169e9eac 9. /build/src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001696565c 10. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016940972 11. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 12. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 13. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 16. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 17. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 18. /build/src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000015cae3aa 19. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 20. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 21. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 22. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 23. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 24. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 28. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:05:35.044561 [ 3542 ] {bb5a41ee-fa42-40d5-a3b0-974725fb9c31} executeQuery: Code: 469. DB::Exception: Constraint `is_censor` for table test_ef9zyjj9.constrained (1ece5be7-53ba-454a-8ab2-ab1f8a6fb5c4) is violated at row 2. Expression: (domainWithoutWWW(URL) = 'censor.net'). Column values: URL = 'Hello'. (VIOLATED_CONSTRAINT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60392) (comment: 00998_constraints_all_tables.sql) (query 3, line 3) (in query: INSERT INTO constrained VALUES ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&) @ 0x0000000013bf7039 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000016b2113c 5. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 7. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 10. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 11. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000168e3c3f 12. /build/src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001681130c 13. /build/src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x0000000016806e9c 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:05:35.066368 [ 3542 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `is_censor` for table test_ef9zyjj9.constrained (1ece5be7-53ba-454a-8ab2-ab1f8a6fb5c4) is violated at row 2. Expression: (domainWithoutWWW(URL) = 'censor.net'). Column values: URL = 'Hello'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&) @ 0x0000000013bf7039 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000016b2113c 5. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 7. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 10. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 11. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000168e3c3f 12. /build/src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001681130c 13. /build/src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x0000000016806e9c 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:05:35.312687 [ 3542 ] {223a2756-b2cb-4f2c-b0db-dd90b78ac506} executeQuery: Code: 469. DB::Exception: Constraint `is_utf8` for table test_ef9zyjj9.constrained (1ece5be7-53ba-454a-8ab2-ab1f8a6fb5c4) is violated at row 3. Expression: (isValidUTF8(URL)). Column values: URL = 'https://censor.net/teÿst'. (VIOLATED_CONSTRAINT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60392) (comment: 00998_constraints_all_tables.sql) (query 4, line 4) (in query: INSERT INTO constrained VALUES ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&) @ 0x0000000013bf7039 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000016b2113c 5. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 7. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 10. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 11. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000168e3c3f 12. /build/src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001681130c 13. /build/src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x0000000016806e9c 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:05:35.327973 [ 3542 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `is_utf8` for table test_ef9zyjj9.constrained (1ece5be7-53ba-454a-8ab2-ab1f8a6fb5c4) is violated at row 3. Expression: (isValidUTF8(URL)). Column values: URL = 'https://censor.net/teÿst'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&) @ 0x0000000013bf7039 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000016b2113c 5. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 7. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 10. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 11. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000168e3c3f 12. /build/src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001681130c 13. /build/src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x0000000016806e9c 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:05:35.460131 [ 6637 ] {757c5e30-313f-46e5-a138-93ead4686108} executeQuery: Code: 632. DB::Exception: Unexpected data 'trash' after parsed Map value '{1:2,2:3}': (while reading the value of key x): (in file/uri /var/lib/clickhouse/user_files/test_i57376yt): While executing JSONCompactEachRowRowInputFormat: While executing File. (UNEXPECTED_DATA_AFTER_PARSED_VALUE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60422) (comment: 02118_deserialize_whole_text.sh) (query 1, line 1) (in query: SELECT * FROM file('test_i57376yt', 'JSONCompactStringsEachRow', 'x Map(UInt32, UInt32)')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&) @ 0x00000000138567eb 4. /build/src/DataTypes/Serializations/ISerialization.cpp:499: DB::ISerialization::throwUnexpectedDataAfterParsedValue(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, String const&) const @ 0x0000000013ba210b 5. /build/src/DataTypes/Serializations/SerializationMap.cpp:243: DB::SerializationMap::deserializeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x0000000013bec806 6. /build/src/DataTypes/Serializations/SerializationNullable.cpp:597: void DB::deserializeWholeTextImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x0000000013bf5ed4 7. /build/src/DataTypes/Serializations/SerializationNullable.cpp:622: DB::SerializationNullable::deserializeNullAsDefaultOrNestedWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000013bf478b 8. /build/src/Formats/JSONUtils.cpp:286: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x0000000016888f7d 9. /build/src/Processors/Formats/Impl/JSONCompactEachRowRowInputFormat.cpp:132: DB::JSONCompactEachRowFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000169e9eac 10. /build/src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001696565c 11. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016940972 12. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 13. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 14. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 18. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 19. /build/src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000015cae3aa 20. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 21. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 22. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 23. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 24. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 25. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:05:35.551641 [ 6637 ] {} TCPHandler: Code: 632. DB::Exception: Unexpected data 'trash' after parsed Map value '{1:2,2:3}': (while reading the value of key x): (in file/uri /var/lib/clickhouse/user_files/test_i57376yt): While executing JSONCompactEachRowRowInputFormat: While executing File. (UNEXPECTED_DATA_AFTER_PARSED_VALUE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&) @ 0x00000000138567eb 4. /build/src/DataTypes/Serializations/ISerialization.cpp:499: DB::ISerialization::throwUnexpectedDataAfterParsedValue(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, String const&) const @ 0x0000000013ba210b 5. /build/src/DataTypes/Serializations/SerializationMap.cpp:243: DB::SerializationMap::deserializeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x0000000013bec806 6. /build/src/DataTypes/Serializations/SerializationNullable.cpp:597: void DB::deserializeWholeTextImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x0000000013bf5ed4 7. /build/src/DataTypes/Serializations/SerializationNullable.cpp:622: DB::SerializationNullable::deserializeNullAsDefaultOrNestedWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000013bf478b 8. /build/src/Formats/JSONUtils.cpp:286: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x0000000016888f7d 9. /build/src/Processors/Formats/Impl/JSONCompactEachRowRowInputFormat.cpp:132: DB::JSONCompactEachRowFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000169e9eac 10. /build/src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001696565c 11. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016940972 12. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 13. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 14. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 18. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 19. /build/src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000015cae3aa 20. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 21. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 22. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 23. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 24. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 25. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:05:36.615483 [ 3542 ] {b45e956e-029a-49d2-895e-179374dad57b} executeQuery: Code: 469. DB::Exception: Constraint `is_censor` for table test_ef9zyjj9.constrained (5f025fbe-ae4f-4e4a-9c9b-747cc8f0ea15) is violated at row 2. Expression: (domainWithoutWWW(URL) = 'censor.net'). Column values: URL = 'Hello'. (VIOLATED_CONSTRAINT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60392) (comment: 00998_constraints_all_tables.sql) (query 8, line 9) (in query: INSERT INTO constrained VALUES ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&) @ 0x0000000013bf7039 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000016b2113c 5. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 7. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 10. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 11. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000168e3c3f 12. /build/src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001681130c 13. /build/src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x0000000016806e9c 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:05:36.636757 [ 3542 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `is_censor` for table test_ef9zyjj9.constrained (5f025fbe-ae4f-4e4a-9c9b-747cc8f0ea15) is violated at row 2. Expression: (domainWithoutWWW(URL) = 'censor.net'). Column values: URL = 'Hello'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&) @ 0x0000000013bf7039 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000016b2113c 5. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 7. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 10. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 11. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000168e3c3f 12. /build/src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001681130c 13. /build/src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x0000000016806e9c 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:05:36.732399 [ 6615 ] {a15c0d7b-dd4d-41ad-a00a-f1ef1f91886a} executeQuery: Code: 632. DB::Exception: Unexpected data 'trash' after parsed Tuple value '(1,2)': (while reading the value of key x): (in file/uri /var/lib/clickhouse/user_files/test_i57376yt): While executing JSONCompactEachRowRowInputFormat: While executing File. (UNEXPECTED_DATA_AFTER_PARSED_VALUE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60464) (comment: 02118_deserialize_whole_text.sh) (query 1, line 1) (in query: SELECT * FROM file('test_i57376yt', 'JSONCompactStringsEachRow', 'x Tuple(UInt32, UInt32)')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&) @ 0x00000000138567eb 4. /build/src/DataTypes/Serializations/ISerialization.cpp:499: DB::ISerialization::throwUnexpectedDataAfterParsedValue(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, String const&) const @ 0x0000000013ba210b 5. /build/src/DataTypes/Serializations/SerializationTuple.cpp:213: void DB::SerializationTuple::deserializeTextImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const::'lambda'()::operator()() const @ 0x0000000013c48806 6. /build/src/DataTypes/Serializations/SerializationTuple.cpp:90: void DB::SerializationTuple::deserializeTextImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x0000000013c4765d 7. /build/src/DataTypes/Serializations/SerializationNullable.cpp:597: void DB::deserializeWholeTextImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x0000000013bf5ed4 8. /build/src/DataTypes/Serializations/SerializationNullable.cpp:622: DB::SerializationNullable::deserializeNullAsDefaultOrNestedWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000013bf478b 9. /build/src/Formats/JSONUtils.cpp:286: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x0000000016888f7d 10. /build/src/Processors/Formats/Impl/JSONCompactEachRowRowInputFormat.cpp:132: DB::JSONCompactEachRowFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000169e9eac 11. /build/src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001696565c 12. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016940972 13. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 14. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 15. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 16. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 17. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 18. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 19. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 20. /build/src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000015cae3aa 21. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 22. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 23. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 24. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 25. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 26. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 28. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 30. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 31. ? @ 0x00007f7210eb6ac3 2025.07.13 02:05:36.801413 [ 6615 ] {} TCPHandler: Code: 632. DB::Exception: Unexpected data 'trash' after parsed Tuple value '(1,2)': (while reading the value of key x): (in file/uri /var/lib/clickhouse/user_files/test_i57376yt): While executing JSONCompactEachRowRowInputFormat: While executing File. (UNEXPECTED_DATA_AFTER_PARSED_VALUE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&) @ 0x00000000138567eb 4. /build/src/DataTypes/Serializations/ISerialization.cpp:499: DB::ISerialization::throwUnexpectedDataAfterParsedValue(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, String const&) const @ 0x0000000013ba210b 5. /build/src/DataTypes/Serializations/SerializationTuple.cpp:213: void DB::SerializationTuple::deserializeTextImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const::'lambda'()::operator()() const @ 0x0000000013c48806 6. /build/src/DataTypes/Serializations/SerializationTuple.cpp:90: void DB::SerializationTuple::deserializeTextImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x0000000013c4765d 7. /build/src/DataTypes/Serializations/SerializationNullable.cpp:597: void DB::deserializeWholeTextImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x0000000013bf5ed4 8. /build/src/DataTypes/Serializations/SerializationNullable.cpp:622: DB::SerializationNullable::deserializeNullAsDefaultOrNestedWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000013bf478b 9. /build/src/Formats/JSONUtils.cpp:286: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x0000000016888f7d 10. /build/src/Processors/Formats/Impl/JSONCompactEachRowRowInputFormat.cpp:132: DB::JSONCompactEachRowFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000169e9eac 11. /build/src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001696565c 12. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016940972 13. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 14. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 15. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 16. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 17. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 18. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 19. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 20. /build/src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000015cae3aa 21. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 22. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 23. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 24. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 25. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 26. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 28. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 30. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 31. ? @ 0x00007f7210eb6ac3 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:05:37.114271 [ 3542 ] {bd2d0474-31ac-4b77-903b-6f5df6d14fde} executeQuery: Code: 469. DB::Exception: Constraint `is_utf8` for table test_ef9zyjj9.constrained (5f025fbe-ae4f-4e4a-9c9b-747cc8f0ea15) is violated at row 3. Expression: (isValidUTF8(URL)). Column values: URL = 'https://censor.net/teÿst'. (VIOLATED_CONSTRAINT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60392) (comment: 00998_constraints_all_tables.sql) (query 10, line 11) (in query: INSERT INTO constrained VALUES ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&) @ 0x0000000013bf7039 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000016b2113c 5. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 7. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 10. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 11. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000168e3c3f 12. /build/src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001681130c 13. /build/src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x0000000016806e9c 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:05:37.138083 [ 3542 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `is_utf8` for table test_ef9zyjj9.constrained (5f025fbe-ae4f-4e4a-9c9b-747cc8f0ea15) is violated at row 3. Expression: (isValidUTF8(URL)). Column values: URL = 'https://censor.net/teÿst'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&) @ 0x0000000013bf7039 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000016b2113c 5. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 7. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 10. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 11. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000168e3c3f 12. /build/src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001681130c 13. /build/src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x0000000016806e9c 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:05:37.677628 [ 6637 ] {f801c30c-2b11-49d7-86a4-a56a0f7a71ef} executeQuery: Code: 43. DB::Exception: Point's component must not be NaN: In scope SELECT arrayMap(a -> arrayMap(b -> arrayMap(c -> (round(c.1, 6), round(c.2, 6)), b), a), polygonsUnionCartesian([[[(2., 100.0000991821289), (0., 3.), (1., 2.9), (2., 2.6), (2.6, 2.), (2.9, 1), (3., 0.), (100.0000991821289, 2.)]]], [[[(1., 1.), (1000.0001220703125, nan), (4., 4.), (4., 1.), (1., 1.)]]])). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60502) (comment: 01305_polygons_union.sql) (query 2, line 3) (in query: SELECT arrayMap(a -> arrayMap(b -> arrayMap(c -> (round(c.1, 6), round(c.2, 6)), b), a), polygonsUnionCartesian([[[(2., 100.0000991821289), (0., 3.), (1., 2.9), (2., 2.6), (2.6, 2.), (2.9, 1), (3., 0.), (100.0000991821289, 2.)]]], [[[(1., 1.), (1000.0001220703125, nan), (4., 4.), (4., 1.), (1., 1.)]]]));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/geometryConverters.h:86: DB::ColumnToPointsConverter>::convert(COW::immutable_ptr) @ 0x000000000e00c3f6 5. /build/src/Functions/geometryConverters.h:155: DB::ColumnToRingsConverter>::convert(COW::immutable_ptr) @ 0x000000000e00d230 6. /build/src/Functions/geometryConverters.h:175: DB::ColumnToPolygonsConverter>::convert(COW::immutable_ptr) @ 0x000000000e00db7d 7. /build/src/Functions/geometryConverters.h:210: DB::ColumnToMultiPolygonsConverter>::convert(COW::immutable_ptr) @ 0x000000000e00e9e1 8. /build/src/Functions/polygonsUnion.cpp:81: void DB::callOnGeometryDataType, void DB::callOnTwoGeometryDataTypes, DB::(anonymous namespace)::FunctionPolygonsUnion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, auto const&)>(std::shared_ptr, std::shared_ptr, auto&&)::'lambda'(auto const&)>(std::shared_ptr, auto&&) @ 0x000000000e3c8f0c 9. /build/src/Functions/geometryConverters.h:493: DB::(anonymous namespace)::FunctionPolygonsUnion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e3c55f9 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 26. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 27. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 31. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 2025.07.13 02:05:37.696560 [ 6637 ] {} TCPHandler: Code: 43. DB::Exception: Point's component must not be NaN: In scope SELECT arrayMap(a -> arrayMap(b -> arrayMap(c -> (round(c.1, 6), round(c.2, 6)), b), a), polygonsUnionCartesian([[[(2., 100.0000991821289), (0., 3.), (1., 2.9), (2., 2.6), (2.6, 2.), (2.9, 1), (3., 0.), (100.0000991821289, 2.)]]], [[[(1., 1.), (1000.0001220703125, nan), (4., 4.), (4., 1.), (1., 1.)]]])). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/geometryConverters.h:86: DB::ColumnToPointsConverter>::convert(COW::immutable_ptr) @ 0x000000000e00c3f6 5. /build/src/Functions/geometryConverters.h:155: DB::ColumnToRingsConverter>::convert(COW::immutable_ptr) @ 0x000000000e00d230 6. /build/src/Functions/geometryConverters.h:175: DB::ColumnToPolygonsConverter>::convert(COW::immutable_ptr) @ 0x000000000e00db7d 7. /build/src/Functions/geometryConverters.h:210: DB::ColumnToMultiPolygonsConverter>::convert(COW::immutable_ptr) @ 0x000000000e00e9e1 8. /build/src/Functions/polygonsUnion.cpp:81: void DB::callOnGeometryDataType, void DB::callOnTwoGeometryDataTypes, DB::(anonymous namespace)::FunctionPolygonsUnion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, auto const&)>(std::shared_ptr, std::shared_ptr, auto&&)::'lambda'(auto const&)>(std::shared_ptr, auto&&) @ 0x000000000e3c8f0c 9. /build/src/Functions/geometryConverters.h:493: DB::(anonymous namespace)::FunctionPolygonsUnion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e3c55f9 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 26. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 27. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 31. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 2025.07.13 02:05:37.853073 [ 3543 ] {8c89330a-fce6-4c19-8c5e-df3ec4b9d193} executeQuery: Code: 632. DB::Exception: Unexpected data 'trash' after parsed UUID value 'ed9fd45d-6287-47c1-ad9f-d45d628767c1': (while reading the value of key x): (in file/uri /var/lib/clickhouse/user_files/test_i57376yt): While executing JSONCompactEachRowRowInputFormat: While executing File. (UNEXPECTED_DATA_AFTER_PARSED_VALUE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60520) (comment: 02118_deserialize_whole_text.sh) (query 1, line 1) (in query: SELECT * FROM file('test_i57376yt', 'JSONCompactStringsEachRow', 'x UUID')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&) @ 0x00000000138567eb 4. /build/src/DataTypes/Serializations/ISerialization.cpp:499: DB::ISerialization::throwUnexpectedDataAfterParsedValue(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, String const&) const @ 0x0000000013ba210b 5. /build/src/DataTypes/Serializations/SerializationUUID.cpp:25: DB::SerializationUUID::deserializeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x0000000013c4ec5d 6. /build/src/DataTypes/Serializations/SerializationNullable.cpp:597: void DB::deserializeWholeTextImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x0000000013bf5ed4 7. /build/src/DataTypes/Serializations/SerializationNullable.cpp:622: DB::SerializationNullable::deserializeNullAsDefaultOrNestedWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000013bf478b 8. /build/src/Formats/JSONUtils.cpp:286: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x0000000016888f7d 9. /build/src/Processors/Formats/Impl/JSONCompactEachRowRowInputFormat.cpp:132: DB::JSONCompactEachRowFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000169e9eac 10. /build/src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001696565c 11. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016940972 12. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 13. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 14. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 18. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 19. /build/src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000015cae3aa 20. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 21. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 22. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 23. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 24. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 25. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:05:37.988091 [ 3543 ] {} TCPHandler: Code: 632. DB::Exception: Unexpected data 'trash' after parsed UUID value 'ed9fd45d-6287-47c1-ad9f-d45d628767c1': (while reading the value of key x): (in file/uri /var/lib/clickhouse/user_files/test_i57376yt): While executing JSONCompactEachRowRowInputFormat: While executing File. (UNEXPECTED_DATA_AFTER_PARSED_VALUE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&) @ 0x00000000138567eb 4. /build/src/DataTypes/Serializations/ISerialization.cpp:499: DB::ISerialization::throwUnexpectedDataAfterParsedValue(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, String const&) const @ 0x0000000013ba210b 5. /build/src/DataTypes/Serializations/SerializationUUID.cpp:25: DB::SerializationUUID::deserializeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x0000000013c4ec5d 6. /build/src/DataTypes/Serializations/SerializationNullable.cpp:597: void DB::deserializeWholeTextImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x0000000013bf5ed4 7. /build/src/DataTypes/Serializations/SerializationNullable.cpp:622: DB::SerializationNullable::deserializeNullAsDefaultOrNestedWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000013bf478b 8. /build/src/Formats/JSONUtils.cpp:286: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x0000000016888f7d 9. /build/src/Processors/Formats/Impl/JSONCompactEachRowRowInputFormat.cpp:132: DB::JSONCompactEachRowFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000169e9eac 10. /build/src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001696565c 11. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016940972 12. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 13. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 14. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 18. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 19. /build/src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000015cae3aa 20. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 21. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 22. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 23. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 24. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 25. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:05:38.860668 [ 3542 ] {9ecc2218-b9a2-4b56-9c5d-a8694f9f3504} executeQuery: Code: 469. DB::Exception: Constraint `is_censor` for table test_ef9zyjj9.constrained (1eb31153-6cd9-4eff-8131-0e19552ebda1) is violated at row 2. Expression: (domainWithoutWWW(URL) = 'censor.net'). Column values: URL = 'Hello'. (VIOLATED_CONSTRAINT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60392) (comment: 00998_constraints_all_tables.sql) (query 16, line 18) (in query: INSERT INTO constrained VALUES ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&) @ 0x0000000013bf7039 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000016b2113c 5. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 7. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 10. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 11. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000168e3c3f 12. /build/src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001681130c 13. /build/src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x0000000016806e9c 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:05:38.873260 [ 3542 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `is_censor` for table test_ef9zyjj9.constrained (1eb31153-6cd9-4eff-8131-0e19552ebda1) is violated at row 2. Expression: (domainWithoutWWW(URL) = 'censor.net'). Column values: URL = 'Hello'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&) @ 0x0000000013bf7039 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000016b2113c 5. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 7. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 10. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 11. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000168e3c3f 12. /build/src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001681130c 13. /build/src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x0000000016806e9c 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:05:39.303036 [ 3542 ] {8ebdb808-4fdf-4214-9950-f9016f6c96c8} executeQuery: Code: 469. DB::Exception: Constraint `is_utf8` for table test_ef9zyjj9.constrained (1eb31153-6cd9-4eff-8131-0e19552ebda1) is violated at row 3. Expression: (isValidUTF8(URL)). Column values: URL = 'https://censor.net/teÿst'. (VIOLATED_CONSTRAINT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60392) (comment: 00998_constraints_all_tables.sql) (query 18, line 20) (in query: INSERT INTO constrained VALUES ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&) @ 0x0000000013bf7039 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000016b2113c 5. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 7. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 10. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 11. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000168e3c3f 12. /build/src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001681130c 13. /build/src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x0000000016806e9c 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:05:39.336346 [ 3542 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `is_utf8` for table test_ef9zyjj9.constrained (1eb31153-6cd9-4eff-8131-0e19552ebda1) is violated at row 3. Expression: (isValidUTF8(URL)). Column values: URL = 'https://censor.net/teÿst'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&) @ 0x0000000013bf7039 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000016b2113c 5. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 7. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 10. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 11. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000168e3c3f 12. /build/src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001681130c 13. /build/src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x0000000016806e9c 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:05:41.057768 [ 3542 ] {01f6efa4-a409-4e1a-9863-f6a73cd16105} executeQuery: Code: 469. DB::Exception: Constraint `is_censor` for table test_ef9zyjj9.constrained (cde325db-447b-4ba5-b6b2-7ee5e638544a) is violated at row 2. Expression: (domainWithoutWWW(URL) = 'censor.net'). Column values: URL = 'Hello'. (VIOLATED_CONSTRAINT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60392) (comment: 00998_constraints_all_tables.sql) (query 24, line 27) (in query: INSERT INTO constrained VALUES ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&) @ 0x0000000013bf7039 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000016b2113c 5. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 7. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 10. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 11. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000168e3c3f 12. /build/src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001681130c 13. /build/src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x0000000016806e9c 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:05:41.089353 [ 3542 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `is_censor` for table test_ef9zyjj9.constrained (cde325db-447b-4ba5-b6b2-7ee5e638544a) is violated at row 2. Expression: (domainWithoutWWW(URL) = 'censor.net'). Column values: URL = 'Hello'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&) @ 0x0000000013bf7039 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000016b2113c 5. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 7. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 10. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 11. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000168e3c3f 12. /build/src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001681130c 13. /build/src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x0000000016806e9c 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:05:41.639318 [ 3542 ] {820d506e-7f9e-4f41-bded-9c55a25387d5} executeQuery: Code: 469. DB::Exception: Constraint `is_utf8` for table test_ef9zyjj9.constrained (cde325db-447b-4ba5-b6b2-7ee5e638544a) is violated at row 3. Expression: (isValidUTF8(URL)). Column values: URL = 'https://censor.net/teÿst'. (VIOLATED_CONSTRAINT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60392) (comment: 00998_constraints_all_tables.sql) (query 26, line 29) (in query: INSERT INTO constrained VALUES ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&) @ 0x0000000013bf7039 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000016b2113c 5. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 7. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 10. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 11. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000168e3c3f 12. /build/src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001681130c 13. /build/src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x0000000016806e9c 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:05:41.672629 [ 3542 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `is_utf8` for table test_ef9zyjj9.constrained (cde325db-447b-4ba5-b6b2-7ee5e638544a) is violated at row 3. Expression: (isValidUTF8(URL)). Column values: URL = 'https://censor.net/teÿst'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&) @ 0x0000000013bf7039 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000016b2113c 5. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 7. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 10. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 11. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000168e3c3f 12. /build/src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001681130c 13. /build/src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x0000000016806e9c 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:05:43.152595 [ 3542 ] {4181c664-6f32-45e5-90f0-612678925b4a} executeQuery: Code: 469. DB::Exception: Constraint `is_censor` for table test_ef9zyjj9.constrained (b3c11820-d9f9-48e3-aebc-09228822c685) is violated at row 2. Expression: (domainWithoutWWW(URL) = 'censor.net'). Column values: URL = 'Hello'. (VIOLATED_CONSTRAINT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60392) (comment: 00998_constraints_all_tables.sql) (query 32, line 36) (in query: INSERT INTO constrained VALUES ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&) @ 0x0000000013bf7039 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000016b2113c 5. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 7. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 10. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 11. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000168e3c3f 12. /build/src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001681130c 13. /build/src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x0000000016806e9c 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:05:43.210421 [ 3542 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `is_censor` for table test_ef9zyjj9.constrained (b3c11820-d9f9-48e3-aebc-09228822c685) is violated at row 2. Expression: (domainWithoutWWW(URL) = 'censor.net'). Column values: URL = 'Hello'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&) @ 0x0000000013bf7039 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000016b2113c 5. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 7. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 10. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 11. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000168e3c3f 12. /build/src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001681130c 13. /build/src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x0000000016806e9c 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:05:43.653446 [ 3542 ] {600aa6b9-0582-4cf0-8cbb-c178385825c0} executeQuery: Code: 469. DB::Exception: Constraint `is_utf8` for table test_ef9zyjj9.constrained (b3c11820-d9f9-48e3-aebc-09228822c685) is violated at row 3. Expression: (isValidUTF8(URL)). Column values: URL = 'https://censor.net/teÿst'. (VIOLATED_CONSTRAINT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60392) (comment: 00998_constraints_all_tables.sql) (query 34, line 38) (in query: INSERT INTO constrained VALUES ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&) @ 0x0000000013bf7039 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000016b2113c 5. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 7. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 10. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 11. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000168e3c3f 12. /build/src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001681130c 13. /build/src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x0000000016806e9c 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:05:43.680700 [ 3542 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `is_utf8` for table test_ef9zyjj9.constrained (b3c11820-d9f9-48e3-aebc-09228822c685) is violated at row 3. Expression: (isValidUTF8(URL)). Column values: URL = 'https://censor.net/teÿst'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&) @ 0x0000000013bf7039 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000016b2113c 5. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 7. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 10. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 11. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000168e3c3f 12. /build/src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001681130c 13. /build/src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x0000000016806e9c 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:05:44.895470 [ 6166 ] {66543adf-b8b3-46b4-81d2-9138db281189} executeQuery: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 2923150000 microseconds per block (of size 58463): while executing 'FUNCTION sleepEachRow(0.05_Float64 :: 1) -> sleepEachRow(0.05_Float64) UInt8 : 0'. (TOO_SLOW) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37828) (comment: 02725_sleep_max_time.sql) (query 1, line 1) (in query: SELECT * FROM system.numbers WHERE sleepEachRow(0.05) LIMIT 10;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000000e5e92ab 4. /build/src/Functions/sleep.cpp:143: DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000000e5e917d 5. /build/src/Functions/sleep.cpp:106: DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e5e8a2c 6. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 7. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 10. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 11. /build/src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000016b34094 12. /build/src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000016b33fb4 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:05:44.934483 [ 6166 ] {} TCPHandler: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 2923150000 microseconds per block (of size 58463): while executing 'FUNCTION sleepEachRow(0.05_Float64 :: 1) -> sleepEachRow(0.05_Float64) UInt8 : 0'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000000e5e92ab 4. /build/src/Functions/sleep.cpp:143: DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000000e5e917d 5. /build/src/Functions/sleep.cpp:106: DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e5e8a2c 6. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 7. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 10. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 11. /build/src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000016b34094 12. /build/src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000016b33fb4 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:05:45.355699 [ 4922 ] {304d166c-3a14-4ad7-95ca-1bef2a39df71} executeQuery: Code: 57. DB::Exception: Table test_13.t already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37846) (comment: 02499_monotonicity_toUnixTimestamp64.sh) (query 1, line 1) (in query: create table t(ts DateTime64) engine=MergeTree order by ts as select * from numbers_mt(1e6);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:05:45.404316 [ 4922 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:05:45.923326 [ 4922 ] {test_13_02499_3259120369} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `ts` in scope SELECT ts FROM t ORDER BY toUnixTimestamp64Nano(ts) ASC LIMIT 10. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37862) (comment: 02499_monotonicity_toUnixTimestamp64.sh) (query 1, line 1) (in query: select ts from t order by toUnixTimestamp64Nano(ts) limit 10 format Null settings max_block_size = 8192, optimize_read_in_order = 1, max_threads = 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000013f69e39 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f3a889 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:05:45.945506 [ 3543 ] {de9c0b19-40e1-4c4b-bd6d-8329efdc6d66} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function gcd: In scope SELECT gcd(1280.1, 1024.1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37752) (comment: 00515_gcd_lcm.sql) (query 24, line 26) (in query: -- test gcd float select gcd(1280.1, 1024.1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000b94f4d3 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:05:46.003537 [ 3543 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function gcd: In scope SELECT gcd(1280.1, 1024.1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000b94f4d3 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:05:46.003806 [ 4922 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `ts` in scope SELECT ts FROM t ORDER BY toUnixTimestamp64Nano(ts) ASC LIMIT 10. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000013f69e39 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f3a889 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:05:46.159434 [ 3543 ] {2134edf0-d918-4dd2-a490-11461b03f99f} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function gcd: In scope SELECT gcd(11.1, 121.1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37752) (comment: 00515_gcd_lcm.sql) (query 25, line 28) (in query: select gcd(11.1, 121.1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000b94f4d3 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:05:46.183808 [ 3543 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function gcd: In scope SELECT gcd(11.1, 121.1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000b94f4d3 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:05:46.295827 [ 3543 ] {f2e46796-fb02-4093-bd3e-656c53f73015} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function gcd: In scope SELECT gcd(-256.1, 64.1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37752) (comment: 00515_gcd_lcm.sql) (query 26, line 29) (in query: select gcd(-256.1, 64.1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000b94f4d3 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:05:46.310003 [ 3543 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function gcd: In scope SELECT gcd(-256.1, 64.1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000b94f4d3 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:05:46.422442 [ 3542 ] {d219b763-3fd4-495d-afe7-fccb4042108b} executeQuery: Code: 469. DB::Exception: Constraint `is_censor` for table test_ef9zyjj9.constrained (155c39fe-bc77-4aee-b74b-413f2c566b9a) is violated at row 2. Expression: (domainWithoutWWW(URL) = 'censor.net'). Column values: URL = 'Hello'. (VIOLATED_CONSTRAINT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60392) (comment: 00998_constraints_all_tables.sql) (query 44, line 50) (in query: INSERT INTO constrained VALUES ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&) @ 0x0000000013bf7039 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000016b2113c 5. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 7. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 10. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 11. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000168e3c3f 12. /build/src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001681130c 13. /build/src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x0000000016806e9c 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:05:46.430862 [ 3542 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `is_censor` for table test_ef9zyjj9.constrained (155c39fe-bc77-4aee-b74b-413f2c566b9a) is violated at row 2. Expression: (domainWithoutWWW(URL) = 'censor.net'). Column values: URL = 'Hello'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&) @ 0x0000000013bf7039 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000016b2113c 5. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 7. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 10. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 11. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000168e3c3f 12. /build/src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001681130c 13. /build/src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x0000000016806e9c 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:05:46.573966 [ 6615 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000013779f8b 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000137794b8 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778bc3 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678d325 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:46.606597 [ 3543 ] {50176010-24d6-4cde-af74-7aa763cf3c08} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function gcd: In scope SELECT gcd(1.1, 1.1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37752) (comment: 00515_gcd_lcm.sql) (query 27, line 30) (in query: select gcd(1.1, 1.1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000b94f4d3 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:05:46.674224 [ 3543 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function gcd: In scope SELECT gcd(1.1, 1.1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000b94f4d3 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:05:46.796289 [ 3543 ] {af5a7425-0a65-448c-9515-c732ada987a8} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function gcd: In scope SELECT gcd(4.1, 2.1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37752) (comment: 00515_gcd_lcm.sql) (query 28, line 31) (in query: select gcd(4.1, 2.1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000b94f4d3 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:05:46.812302 [ 3542 ] {a06da769-22a4-45db-9380-a43e2957cf33} executeQuery: Code: 469. DB::Exception: Constraint `is_censor` for table test_ef9zyjj9.constrained2 (c092f7ad-7713-4ae7-ba06-ac2614309087) is violated at row 2. Expression: (domainWithoutWWW(URL) = 'censor.net'). Column values: URL = 'Hello'. (VIOLATED_CONSTRAINT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60392) (comment: 00998_constraints_all_tables.sql) (query 45, line 51) (in query: INSERT INTO constrained2 VALUES ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&) @ 0x0000000013bf7039 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000016b2113c 5. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 7. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 10. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 11. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000168e3c3f 12. /build/src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001681130c 13. /build/src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x0000000016806e9c 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:05:46.825342 [ 3543 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function gcd: In scope SELECT gcd(4.1, 2.1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000b94f4d3 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:05:46.840445 [ 3542 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `is_censor` for table test_ef9zyjj9.constrained2 (c092f7ad-7713-4ae7-ba06-ac2614309087) is violated at row 2. Expression: (domainWithoutWWW(URL) = 'censor.net'). Column values: URL = 'Hello'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&) @ 0x0000000013bf7039 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000016b2113c 5. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 7. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 10. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 11. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000168e3c3f 12. /build/src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001681130c 13. /build/src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x0000000016806e9c 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:05:46.960954 [ 3543 ] {95b70276-2d13-4800-83b2-382bec977a41} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function gcd: In scope SELECT gcd(15.1, 49.1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37752) (comment: 00515_gcd_lcm.sql) (query 29, line 32) (in query: select gcd(15.1, 49.1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000b94f4d3 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:05:46.992165 [ 3543 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function gcd: In scope SELECT gcd(15.1, 49.1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000b94f4d3 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:05:47.165275 [ 3543 ] {e828659c-245c-4d78-a8c2-1f2d2009351d} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function gcd: In scope SELECT gcd(255.1, 254.1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37752) (comment: 00515_gcd_lcm.sql) (query 30, line 33) (in query: select gcd(255.1, 254.1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000b94f4d3 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:05:47.175216 [ 3543 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function gcd: In scope SELECT gcd(255.1, 254.1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000b94f4d3 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:05:47.525458 [ 3543 ] {c9e4e0e1-6bd2-44b9-a875-c765851d7d28} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function lcm: In scope SELECT lcm(1280.1, 1024.1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37752) (comment: 00515_gcd_lcm.sql) (query 31, line 34) (in query: -- test lcm float select lcm(1280.1, 1024.1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000c7a9173 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:05:47.551001 [ 3543 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function lcm: In scope SELECT lcm(1280.1, 1024.1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000c7a9173 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:05:47.756667 [ 3543 ] {a0f76a1e-d45c-463a-b215-92c9152fec8f} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function lcm: In scope SELECT lcm(11.1, 121.1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37752) (comment: 00515_gcd_lcm.sql) (query 32, line 36) (in query: select lcm(11.1, 121.1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000c7a9173 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:05:47.762887 [ 3543 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function lcm: In scope SELECT lcm(11.1, 121.1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000c7a9173 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:05:47.827931 [ 3543 ] {303d5450-b9e7-4f15-b77d-e19bc384bf13} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function lcm: In scope SELECT lcm(-256.1, 64.1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37752) (comment: 00515_gcd_lcm.sql) (query 33, line 37) (in query: select lcm(-256.1, 64.1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000c7a9173 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:05:47.842135 [ 3543 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function lcm: In scope SELECT lcm(-256.1, 64.1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000c7a9173 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:05:48.008082 [ 3543 ] {63576ffa-8684-454b-9d9e-a9e4e3ce77e3} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function lcm: In scope SELECT lcm(1.1, 1.1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37752) (comment: 00515_gcd_lcm.sql) (query 34, line 38) (in query: select lcm(1.1, 1.1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000c7a9173 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:05:48.050591 [ 3543 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function lcm: In scope SELECT lcm(1.1, 1.1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000c7a9173 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:05:48.127998 [ 3543 ] {f6d31813-46b0-4227-a3b1-6a1d52db9c3f} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function lcm: In scope SELECT lcm(4.1, 2.1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37752) (comment: 00515_gcd_lcm.sql) (query 35, line 39) (in query: select lcm(4.1, 2.1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000c7a9173 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:05:48.134827 [ 3543 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function lcm: In scope SELECT lcm(4.1, 2.1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000c7a9173 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:05:48.281129 [ 3543 ] {060078bf-e8e4-4cd4-8827-d7e68a2d4f0b} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function lcm: In scope SELECT lcm(15.1, 49.1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37752) (comment: 00515_gcd_lcm.sql) (query 36, line 40) (in query: select lcm(15.1, 49.1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000c7a9173 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:05:48.288693 [ 3543 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function lcm: In scope SELECT lcm(15.1, 49.1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000c7a9173 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:05:48.445998 [ 3543 ] {e09dd964-a564-4855-93bc-fbad34ed77dd} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function lcm: In scope SELECT lcm(255.1, 254.1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37752) (comment: 00515_gcd_lcm.sql) (query 37, line 41) (in query: select lcm(255.1, 254.1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000c7a9173 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:05:48.472527 [ 3543 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function lcm: In scope SELECT lcm(255.1, 254.1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000c7a9173 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:05:51.165278 [ 4930 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778c58 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168167bf 10. /build/src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000001680ff45 11. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:05:51.176099 [ 4930 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x0000000016810069 5. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 6. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 2025.07.13 02:05:51.753152 [ 6608 ] {c142b84d-5fd4-42d3-a9c2-d441928aa9c5} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Merge. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57076) (comment: 02840_merge__table_or_filter.gen.sql) (in query: DROP DATABASE IF EXISTS test_tyet0nzp SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/IStorage.cpp:171: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015c3ce9a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833683 6. /build/src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835a47 7. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 8. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 9. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 12. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 13. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 14. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:05:51.773329 [ 6608 ] {c142b84d-5fd4-42d3-a9c2-d441928aa9c5} DynamicQueryHandler: Code: 48. DB::Exception: Truncate is not supported by storage Merge. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/IStorage.cpp:171: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015c3ce9a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833683 6. /build/src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835a47 7. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 8. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 9. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 12. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 13. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 14. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:05:57.355420 [ 4015 ] {} DNSResolver: Cannot resolve host (localhos), error 0: Host not found. 2025.07.13 02:05:58.087985 [ 4930 ] {cd1eb5d7-ccf2-43ea-8ba3-6bfd26bc3a9f} 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]:34648) (comment: 02101_empty_as_default_and_omitted_fields.sh) (query 1, line 1) (in query: SELECT * FROM test_02101 ORDER BY x), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 9. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:05:58.110541 [ 4930 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 9. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:05:58.714730 [ 6637 ] {4c4b11aa-545b-4782-a524-49537dea0458} executeQuery: Code: 999. DB::Exception: Fault injection before operation. (KEEPER_EXCEPTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34540) (comment: 02456_keeper_retries_during_insert.sql) (query 6, line 10) (in query: INSERT INTO keeper_retries_r1 SETTINGS insert_keeper_fault_injection_probability=1, insert_keeper_max_retries=0 VALUES ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000170b719e 3. /build/src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000170b4ed0 4. /build/src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:107: DB::ZooKeeperWithFaultInjection::injectFailureBeforeOperationThrow(char const*, String const&) @ 0x00000000170af3c7 5. /build/src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:134: DB::ZooKeeperWithFaultInjection::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x00000000170b0b27 6. /build/src/Storages/StorageReplicatedMergeTree.cpp:7084: DB::StorageReplicatedMergeTree::existsNodeCached(std::shared_ptr const&, String const&) const @ 0x0000000015da5882 7. /build/src/Storages/StorageReplicatedMergeTree.cpp:7121: std::optional DB::StorageReplicatedMergeTree::allocateBlockNumber(String const&, std::shared_ptr const&, String const&, String const&) const @ 0x0000000015ebd8bc 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:898: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x0000000016531613 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x00000000165313d2 10. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000001653125f 11. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x0000000016521b31 12. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000001651695d 13. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x0000000016521355 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 15. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f83c 16. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 17. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 18. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 19. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000168e3c3f 20. /build/src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001681130c 21. /build/src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x0000000016806e9c 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:05:58.778838 [ 6637 ] {} TCPHandler: Code: 999. Coordination::Exception: Fault injection before operation. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000170b719e 3. /build/src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000170b4ed0 4. /build/src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:107: DB::ZooKeeperWithFaultInjection::injectFailureBeforeOperationThrow(char const*, String const&) @ 0x00000000170af3c7 5. /build/src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:134: DB::ZooKeeperWithFaultInjection::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x00000000170b0b27 6. /build/src/Storages/StorageReplicatedMergeTree.cpp:7084: DB::StorageReplicatedMergeTree::existsNodeCached(std::shared_ptr const&, String const&) const @ 0x0000000015da5882 7. /build/src/Storages/StorageReplicatedMergeTree.cpp:7121: std::optional DB::StorageReplicatedMergeTree::allocateBlockNumber(String const&, std::shared_ptr const&, String const&, String const&) const @ 0x0000000015ebd8bc 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:898: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x0000000016531613 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x00000000165313d2 10. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000001653125f 11. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x0000000016521b31 12. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000001651695d 13. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x0000000016521355 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 15. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f83c 16. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 17. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 18. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 19. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000168e3c3f 20. /build/src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001681130c 21. /build/src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x0000000016806e9c 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:06:01.030376 [ 3552 ] {} CgroupsReader: Cannot find 'kernel' in '/sys/fs/cgroup/memory.stat' (skipped 5558 similar messages) 2025.07.13 02:06:01.466612 [ 6637 ] {0406a5e0-6aa5-4b32-84ca-a5cef5dcc413} executeQuery: Code: 999. DB::Exception: Fault injection before operation. (KEEPER_EXCEPTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34540) (comment: 02456_keeper_retries_during_insert.sql) (query 7, line 11) (in query: INSERT INTO keeper_retries_r1 SETTINGS insert_keeper_fault_injection_probability=1, insert_keeper_retry_max_backoff_ms=10 VALUES ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000170b719e 3. /build/src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000170b4ed0 4. /build/src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:107: DB::ZooKeeperWithFaultInjection::injectFailureBeforeOperationThrow(char const*, String const&) @ 0x00000000170af3c7 5. /build/src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:134: DB::ZooKeeperWithFaultInjection::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x00000000170b0b27 6. /build/src/Storages/StorageReplicatedMergeTree.cpp:7084: DB::StorageReplicatedMergeTree::existsNodeCached(std::shared_ptr const&, String const&) const @ 0x0000000015da5882 7. /build/src/Storages/StorageReplicatedMergeTree.cpp:7121: std::optional DB::StorageReplicatedMergeTree::allocateBlockNumber(String const&, std::shared_ptr const&, String const&, String const&) const @ 0x0000000015ebd8bc 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:898: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x0000000016531613 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x00000000165313d2 10. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000001653125f 11. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x0000000016521b31 12. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000001651695d 13. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x0000000016521355 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 15. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f83c 16. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 17. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 18. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 19. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000168e3c3f 20. /build/src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001681130c 21. /build/src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x0000000016806e9c 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:06:01.553858 [ 6637 ] {} TCPHandler: Code: 999. Coordination::Exception: Fault injection before operation. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000170b719e 3. /build/src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000170b4ed0 4. /build/src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:107: DB::ZooKeeperWithFaultInjection::injectFailureBeforeOperationThrow(char const*, String const&) @ 0x00000000170af3c7 5. /build/src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:134: DB::ZooKeeperWithFaultInjection::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x00000000170b0b27 6. /build/src/Storages/StorageReplicatedMergeTree.cpp:7084: DB::StorageReplicatedMergeTree::existsNodeCached(std::shared_ptr const&, String const&) const @ 0x0000000015da5882 7. /build/src/Storages/StorageReplicatedMergeTree.cpp:7121: std::optional DB::StorageReplicatedMergeTree::allocateBlockNumber(String const&, std::shared_ptr const&, String const&, String const&) const @ 0x0000000015ebd8bc 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:898: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x0000000016531613 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x00000000165313d2 10. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000001653125f 11. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x0000000016521b31 12. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000001651695d 13. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x0000000016521355 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 15. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f83c 16. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 17. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 18. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 19. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000168e3c3f 20. /build/src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001681130c 21. /build/src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x0000000016806e9c 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:06:02.373101 [ 6166 ] {a0f02735-c579-4748-bb63-85d4b253d66f} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'timestamp'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT timestamp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34592) (comment: 02834_timestamp_function.sql) (query 21, line 25) (in query: SELECT timestamp();), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000012c9192b 4. /build/src/Functions/FunctionHelpers.cpp:184: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c90171 5. /build/src/Functions/timestamp.cpp:49: DB::(anonymous namespace)::FunctionTimestamp::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e73b10e 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:06:02.408604 [ 6166 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'timestamp'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT timestamp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000012c9192b 4. /build/src/Functions/FunctionHelpers.cpp:184: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c90171 5. /build/src/Functions/timestamp.cpp:49: DB::(anonymous namespace)::FunctionTimestamp::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e73b10e 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:06:02.562446 [ 6166 ] {4ea3c520-d713-468f-80e5-2642e9229c3b} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'timestamp'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT timestamp('2013-12-31 12:00:00', '12:00:00', ''). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34592) (comment: 02834_timestamp_function.sql) (query 22, line 26) (in query: SELECT timestamp('2013-12-31 12:00:00', '12:00:00', '');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000012c9192b 4. /build/src/Functions/FunctionHelpers.cpp:184: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c90171 5. /build/src/Functions/timestamp.cpp:49: DB::(anonymous namespace)::FunctionTimestamp::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e73b10e 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:06:02.577969 [ 6166 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'timestamp'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT timestamp('2013-12-31 12:00:00', '12:00:00', ''). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000012c9192b 4. /build/src/Functions/FunctionHelpers.cpp:184: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c90171 5. /build/src/Functions/timestamp.cpp:49: DB::(anonymous namespace)::FunctionTimestamp::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e73b10e 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:06:02.822155 [ 6166 ] {a308ef40-78be-4605-b117-c5076fd0418c} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'timestamp' to function 'timestamp'. Expected: String or FixedString, got: UInt8: In scope SELECT timestamp(1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34592) (comment: 02834_timestamp_function.sql) (query 23, line 27) (in query: SELECT timestamp(1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/timestamp.cpp:49: DB::(anonymous namespace)::FunctionTimestamp::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e73b10e 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:06:02.871590 [ 6166 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'timestamp' to function 'timestamp'. Expected: String or FixedString, got: UInt8: In scope SELECT timestamp(1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/timestamp.cpp:49: DB::(anonymous namespace)::FunctionTimestamp::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e73b10e 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:06:03.010259 [ 6166 ] {ddabf86c-ff4a-4c7b-a086-5ce9237dee9e} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'timestamp' to function 'timestamp'. Expected: String or FixedString, got: UInt8: In scope SELECT timestamp(1, 2). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34592) (comment: 02834_timestamp_function.sql) (query 24, line 28) (in query: SELECT timestamp(1, 2);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/timestamp.cpp:49: DB::(anonymous namespace)::FunctionTimestamp::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e73b10e 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:06:03.069487 [ 6166 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'timestamp' to function 'timestamp'. Expected: String or FixedString, got: UInt8: In scope SELECT timestamp(1, 2). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/timestamp.cpp:49: DB::(anonymous namespace)::FunctionTimestamp::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e73b10e 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:06:03.396419 [ 6637 ] {268858fd-3a82-4b1c-928f-7af3720c12d5} executeQuery: Code: 999. DB::Exception: Fault injection before operation. (KEEPER_EXCEPTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34540) (comment: 02456_keeper_retries_during_insert.sql) (query 10, line 15) (in query: INSERT INTO keeper_retries_r1 SETTINGS insert_keeper_fault_injection_probability=1, insert_keeper_max_retries=0 VALUES ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000170b719e 3. /build/src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000170b4ed0 4. /build/src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:107: DB::ZooKeeperWithFaultInjection::injectFailureBeforeOperationThrow(char const*, String const&) @ 0x00000000170af3c7 5. /build/src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:134: DB::ZooKeeperWithFaultInjection::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x00000000170b006c 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:226: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000001652faef 7. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000001652f718 8. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x0000000016521129 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000001651f01a 10. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016c130f3 11. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 16. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 17. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000168e3c3f 18. /build/src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001681130c 19. /build/src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x0000000016806e9c 20. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 2025.07.13 02:06:03.417640 [ 6637 ] {} TCPHandler: Code: 999. Coordination::Exception: Fault injection before operation. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000170b719e 3. /build/src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000170b4ed0 4. /build/src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:107: DB::ZooKeeperWithFaultInjection::injectFailureBeforeOperationThrow(char const*, String const&) @ 0x00000000170af3c7 5. /build/src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:134: DB::ZooKeeperWithFaultInjection::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x00000000170b006c 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:226: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000001652faef 7. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000001652f718 8. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x0000000016521129 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000001651f01a 10. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016c130f3 11. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 16. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 17. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000168e3c3f 18. /build/src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001681130c 19. /build/src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x0000000016806e9c 20. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 2025.07.13 02:06:05.521630 [ 6637 ] {308fd392-a46e-4fd4-a79e-29fb442bfc40} executeQuery: Code: 999. DB::Exception: Fault injection before operation. (KEEPER_EXCEPTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34540) (comment: 02456_keeper_retries_during_insert.sql) (query 11, line 16) (in query: INSERT INTO keeper_retries_r1 SETTINGS insert_keeper_fault_injection_probability=1, insert_keeper_retry_max_backoff_ms=1 VALUES ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000170b719e 3. /build/src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000170b4ed0 4. /build/src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:107: DB::ZooKeeperWithFaultInjection::injectFailureBeforeOperationThrow(char const*, String const&) @ 0x00000000170af3c7 5. /build/src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:134: DB::ZooKeeperWithFaultInjection::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x00000000170b006c 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:226: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000001652faef 7. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000001652f718 8. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x0000000016521129 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000001651f01a 10. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016c130f3 11. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 16. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 17. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000168e3c3f 18. /build/src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001681130c 19. /build/src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x0000000016806e9c 20. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 2025.07.13 02:06:05.533255 [ 6637 ] {} TCPHandler: Code: 999. Coordination::Exception: Fault injection before operation. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000170b719e 3. /build/src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000170b4ed0 4. /build/src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:107: DB::ZooKeeperWithFaultInjection::injectFailureBeforeOperationThrow(char const*, String const&) @ 0x00000000170af3c7 5. /build/src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:134: DB::ZooKeeperWithFaultInjection::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x00000000170b006c 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:226: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000001652faef 7. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000001652f718 8. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x0000000016521129 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000001651f01a 10. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016c130f3 11. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 16. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 17. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000168e3c3f 18. /build/src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001681130c 19. /build/src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x0000000016806e9c 20. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 2025.07.13 02:06:06.103912 [ 6166 ] {437f019b-f079-41af-92f5-69171dc5dd1f} executeQuery: Code: 57. DB::Exception: Table test_13.test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37522) (comment: 03173_check_cyclic_dependencies_on_create_and_rename.sql) (query 2, line 4) (in query: CREATE TABLE test (`id` UInt64, `value` String) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 39756, min_bytes_for_wide_part = 374938177, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 62, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 325835004, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 33063204, merge_max_block_size = 14915, old_parts_lifetime = 399., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 65, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 16336106, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 38, 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 = 90126, primary_key_compress_block_size = 45005, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:06:06.143881 [ 6166 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:06:10.013441 [ 4269 ] {5621e1b2-e9e0-446b-a10a-d35f322bb238::all_1_1_0_7} MutatePlainMergeTreeTask: Code: 190. DB::Exception: Elements '[100, 200]' and '['a', 'b', 'c']' of Nested data structure (Array columns) have different array sizes (2 and 3 respectively) on row 0: while executing 'FUNCTION validateNestedArraySizes(equals(id, 0) : 13, [100, 200] :: 5, ['a', 'b', 'c'] :: 6, [10, 20, 30] :: 7) -> validateNestedArraySizes(equals(id, 0), [100, 200], ['a', 'b', 'c'], [10, 20, 30]) UInt8 : 4'. (SIZES_OF_ARRAYS_DONT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:06:10.031824 [ 4870 ] {d148b529-2d63-483d-83e1-30d2c7258806} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_7.txt' with part 'all_1_1_0_6' reason: 'Code: 190. DB::Exception: Elements '[100, 200]' and '['a', 'b', 'c']' of Nested data structure (Array columns) have different array sizes (2 and 3 respectively) on row 0: while executing 'FUNCTION validateNestedArraySizes(equals(id, 0) : 13, [100, 200] :: 5, ['a', 'b', 'c'] :: 6, [10, 20, 30] :: 7) -> validateNestedArraySizes(equals(id, 0), [100, 200], ['a', 'b', 'c'], [10, 20, 30]) UInt8 : 4'. (SIZES_OF_ARRAYS_DONT_MATCH) (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/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Storages/MergeTree/MergeTreeMutationStatus.cpp:33: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x000000001639ba0e 2. /build/src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000001655dce8 3. /build/src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000001655ed84 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd3ec 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 . (UNFINISHED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34692) (comment: 01788_update_nested_type_subcolumn_check.sql) (query 15, line 32) (in query: alter table test_wide_nested update `info.id` = [100,200], `info.age` = [10,20,30], `info.name` = ['a','b','c'] where id = 0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&, String&&) @ 0x000000001639bb59 4. /build/src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x000000001639ba6d 5. /build/src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000001655dce8 6. /build/src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000001655ed84 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd3ec 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:06:10.039609 [ 4870 ] {} TCPHandler: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_7.txt' with part 'all_1_1_0_6' reason: 'Code: 190. DB::Exception: Elements '[100, 200]' and '['a', 'b', 'c']' of Nested data structure (Array columns) have different array sizes (2 and 3 respectively) on row 0: while executing 'FUNCTION validateNestedArraySizes(equals(id, 0) : 13, [100, 200] :: 5, ['a', 'b', 'c'] :: 6, [10, 20, 30] :: 7) -> validateNestedArraySizes(equals(id, 0), [100, 200], ['a', 'b', 'c'], [10, 20, 30]) UInt8 : 4'. (SIZES_OF_ARRAYS_DONT_MATCH) (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/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Storages/MergeTree/MergeTreeMutationStatus.cpp:33: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x000000001639ba0e 2. /build/src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000001655dce8 3. /build/src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000001655ed84 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd3ec 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 . (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&, String&&) @ 0x000000001639bb59 4. /build/src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x000000001639ba6d 5. /build/src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000001655dce8 6. /build/src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000001655ed84 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd3ec 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:06:10.349939 [ 4269 ] {5621e1b2-e9e0-446b-a10a-d35f322bb238::all_1_1_0_7} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 190. DB::Exception: Elements '[100, 200]' and '['a', 'b', 'c']' of Nested data structure (Array columns) have different array sizes (2 and 3 respectively) on row 0: while executing 'FUNCTION validateNestedArraySizes(equals(id, 0) : 13, [100, 200] :: 5, ['a', 'b', 'c'] :: 6, [10, 20, 30] :: 7) -> validateNestedArraySizes(equals(id, 0), [100, 200], ['a', 'b', 'c'], [10, 20, 30]) UInt8 : 4'. (SIZES_OF_ARRAYS_DONT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, unsigned long&, unsigned long&, unsigned long&) @ 0x000000000e8575f9 4. /build/src/Functions/validateNestedArraySizes.cpp:108: DB::FunctionValidateNestedArraySizes::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e857365 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 15. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 16. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 17. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000168e1018 18. /build/src/Storages/MergeTree/MutateTask.cpp:1247: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x000000001644d88e 19. /build/src/Storages/MergeTree/MutateTask.cpp:1162: DB::PartMergerWriter::execute() @ 0x0000000016465874 20. /build/src/Storages/MergeTree/MutateTask.cpp:1741: DB::MutateSomePartColumnsTask::executeStep() @ 0x00000000164660f6 21. /build/src/Storages/MergeTree/MutateTask.cpp:2113: DB::MutateTask::execute() @ 0x000000001644fd0f 22. /build/src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x0000000016594cb8 23. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 28. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:06:10.369157 [ 4269 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {5621e1b2-e9e0-446b-a10a-d35f322bb238::all_1_1_0_7}: Code: 190. DB::Exception: Elements '[100, 200]' and '['a', 'b', 'c']' of Nested data structure (Array columns) have different array sizes (2 and 3 respectively) on row 0: while executing 'FUNCTION validateNestedArraySizes(equals(id, 0) : 13, [100, 200] :: 5, ['a', 'b', 'c'] :: 6, [10, 20, 30] :: 7) -> validateNestedArraySizes(equals(id, 0), [100, 200], ['a', 'b', 'c'], [10, 20, 30]) UInt8 : 4'. (SIZES_OF_ARRAYS_DONT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, unsigned long&, unsigned long&, unsigned long&) @ 0x000000000e8575f9 4. /build/src/Functions/validateNestedArraySizes.cpp:108: DB::FunctionValidateNestedArraySizes::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e857365 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 15. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 16. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 17. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000168e1018 18. /build/src/Storages/MergeTree/MutateTask.cpp:1247: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x000000001644d88e 19. /build/src/Storages/MergeTree/MutateTask.cpp:1162: DB::PartMergerWriter::execute() @ 0x0000000016465874 20. /build/src/Storages/MergeTree/MutateTask.cpp:1741: DB::MutateSomePartColumnsTask::executeStep() @ 0x00000000164660f6 21. /build/src/Storages/MergeTree/MutateTask.cpp:2113: DB::MutateTask::execute() @ 0x000000001644fd0f 22. /build/src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x0000000016594cb8 23. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 28. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:06:11.625734 [ 4870 ] {d2cf3a37-83b2-4e81-a43d-c55e2cdf220f} executeQuery: Code: 57. DB::Exception: Table test_7.test_wide_nested already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34692) (comment: 01788_update_nested_type_subcolumn_check.sql) (query 19, line 40) (in query: CREATE TABLE test_wide_nested (`id` Int, `info.id` Array(Int), `info.name` Array(String), `info.age` Array(Int)) ENGINE = MergeTree ORDER BY tuple() SETTINGS min_bytes_for_wide_part = 0, index_granularity = 5180, 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 = 138153024, compact_parts_max_bytes_to_buffer = 413480321, compact_parts_max_granules_to_buffer = 154, compact_parts_merge_max_bytes_to_prefetch_part = 30734750, merge_max_block_size = 18590, 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 = 2, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 13144607, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 58, 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 = 42983, primary_key_compress_block_size = 37085, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:06:11.648454 [ 4870 ] {} TCPHandler: Code: 57. DB::Exception: Table test_7.test_wide_nested already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:06:12.049409 [ 4267 ] {5621e1b2-e9e0-446b-a10a-d35f322bb238::all_1_1_0_7} MutatePlainMergeTreeTask: Code: 190. DB::Exception: Elements '[100, 200]' and '['a', 'b', 'c']' of Nested data structure (Array columns) have different array sizes (2 and 3 respectively) on row 0: while executing 'FUNCTION validateNestedArraySizes(equals(id, 0) : 13, [100, 200] :: 5, ['a', 'b', 'c'] :: 6, [10, 20, 30] :: 7) -> validateNestedArraySizes(equals(id, 0), [100, 200], ['a', 'b', 'c'], [10, 20, 30]) UInt8 : 4'. (SIZES_OF_ARRAYS_DONT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:06:12.054424 [ 4267 ] {5621e1b2-e9e0-446b-a10a-d35f322bb238::all_1_1_0_7} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 190. DB::Exception: Elements '[100, 200]' and '['a', 'b', 'c']' of Nested data structure (Array columns) have different array sizes (2 and 3 respectively) on row 0: while executing 'FUNCTION validateNestedArraySizes(equals(id, 0) : 13, [100, 200] :: 5, ['a', 'b', 'c'] :: 6, [10, 20, 30] :: 7) -> validateNestedArraySizes(equals(id, 0), [100, 200], ['a', 'b', 'c'], [10, 20, 30]) UInt8 : 4'. (SIZES_OF_ARRAYS_DONT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, unsigned long&, unsigned long&, unsigned long&) @ 0x000000000e8575f9 4. /build/src/Functions/validateNestedArraySizes.cpp:108: DB::FunctionValidateNestedArraySizes::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e857365 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 15. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 16. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 17. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000168e1018 18. /build/src/Storages/MergeTree/MutateTask.cpp:1247: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x000000001644d88e 19. /build/src/Storages/MergeTree/MutateTask.cpp:1162: DB::PartMergerWriter::execute() @ 0x0000000016465874 20. /build/src/Storages/MergeTree/MutateTask.cpp:1741: DB::MutateSomePartColumnsTask::executeStep() @ 0x00000000164660f6 21. /build/src/Storages/MergeTree/MutateTask.cpp:2113: DB::MutateTask::execute() @ 0x000000001644fd0f 22. /build/src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x0000000016594cb8 23. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 28. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:06:12.058352 [ 4267 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {5621e1b2-e9e0-446b-a10a-d35f322bb238::all_1_1_0_7}: Code: 190. DB::Exception: Elements '[100, 200]' and '['a', 'b', 'c']' of Nested data structure (Array columns) have different array sizes (2 and 3 respectively) on row 0: while executing 'FUNCTION validateNestedArraySizes(equals(id, 0) : 13, [100, 200] :: 5, ['a', 'b', 'c'] :: 6, [10, 20, 30] :: 7) -> validateNestedArraySizes(equals(id, 0), [100, 200], ['a', 'b', 'c'], [10, 20, 30]) UInt8 : 4'. (SIZES_OF_ARRAYS_DONT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, unsigned long&, unsigned long&, unsigned long&) @ 0x000000000e8575f9 4. /build/src/Functions/validateNestedArraySizes.cpp:108: DB::FunctionValidateNestedArraySizes::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e857365 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 15. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 16. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 17. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000168e1018 18. /build/src/Storages/MergeTree/MutateTask.cpp:1247: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x000000001644d88e 19. /build/src/Storages/MergeTree/MutateTask.cpp:1162: DB::PartMergerWriter::execute() @ 0x0000000016465874 20. /build/src/Storages/MergeTree/MutateTask.cpp:1741: DB::MutateSomePartColumnsTask::executeStep() @ 0x00000000164660f6 21. /build/src/Storages/MergeTree/MutateTask.cpp:2113: DB::MutateTask::execute() @ 0x000000001644fd0f 22. /build/src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x0000000016594cb8 23. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 28. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:06:15.723080 [ 5018 ] {1e71f3f8-8dbb-4080-a386-f92477c18965} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 109231.016902 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36334) (comment: 03094_grouparraysorted_memory.sql) (query 4, line 36) (in query: INSERT INTO 03094_grouparrysorted_src SELECT * FROM generateRandom() LIMIT 500000;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, unsigned long const&) @ 0x00000000144421ab 4. /build/src/Interpreters/ProcessList.cpp:519: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000001496a7fb 5. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x000000001496af0d 6. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000168d1a5a 7. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0c24 8. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168cfe81 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 2025.07.13 02:06:16.017444 [ 16757 ] {9fa45410-4aa0-4666-94a7-299788690add} executeQuery: Code: 57. DB::Exception: Table test_7.test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42352) (comment: 02790_fix_coredump_when_compile_expression.sql) (query 1, line 1) (in query: CREATE TABLE test (col1 Nullable(DOUBLE), col2 Nullable(DOUBLE), col3 DOUBLE) ENGINE=Memory;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:06:16.047861 [ 16757 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:06:16.829598 [ 6637 ] {27fa6ef1-797c-4429-b457-f15374e7c7cb} 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]:42380) (comment: 03231_pr_duplicate_announcement.sql) (query 2, line 2) (in query: CREATE TABLE test_table (`id` UInt64, `value` String) ENGINE = ReplicatedMergeTree('/clickhouse/test/{database}/test_table', 'r1') ORDER BY tuple() SETTINGS index_granularity = 42614, min_bytes_for_wide_part = 1009448757, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 41, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 515500212, compact_parts_max_granules_to_buffer = 156, compact_parts_merge_max_bytes_to_prefetch_part = 18994246, merge_max_block_size = 10749, old_parts_lifetime = 309., prefer_fetch_merged_part_size_threshold = 4838326574, vertical_merge_algorithm_min_rows_to_activate = 890110, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 26413698, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 48, 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 = 66652, primary_key_compress_block_size = 95998, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:06:16.875228 [ 6637 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:06:17.501432 [ 6619 ] {bf4145a6-03ec-4203-9c2d-057cf3bfb273} 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]:45168) (comment: 03199_queries_with_new_analyzer.sql) (in query: DROP DATABASE IF EXISTS test_tx9kwq9t SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:06:17.505359 [ 6619 ] {bf4145a6-03ec-4203-9c2d-057cf3bfb273} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:06:17.944554 [ 6637 ] {6a29fb5f-7bc0-4e5b-b628-ddb45cf64c29} executeQuery: Code: 57. DB::Exception: Table test_7.t0 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42428) (comment: 01010_partial_merge_join_negative.sql) (query 3, line 4) (in query: CREATE TABLE t0 (`x` UInt32, `y` UInt64) ENGINE = MergeTree ORDER BY (x, y) SETTINGS index_granularity = 40127, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 53, min_bytes_for_full_part_storage = 44485457, compact_parts_max_bytes_to_buffer = 477540250, compact_parts_max_granules_to_buffer = 200, compact_parts_merge_max_bytes_to_prefetch_part = 18467179, merge_max_block_size = 8736, old_parts_lifetime = 187., 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 = 1992630531, index_granularity_bytes = 30629417, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 33, 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 = 78736, primary_key_compress_block_size = 22206, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:06:17.984409 [ 6637 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:06:18.750509 [ 16763 ] {b8c1aeb3-3849-4715-9b0e-468994ae480d} executeQuery: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/03250.zJd31u.binary doesn't exist. (FILE_DOESNT_EXIST) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42494) (comment: 03250_SYSTEM_DROP_FORMAT_SCHEMA_CACHE_FOR_Protobuf.sh) (query 1, line 1) (in query: SELECT count() FROM file('03250.zJd31u.binary', 'Protobuf') FORMAT Null SETTINGS max_threads=1, format_schema='test_11/03250:Numbers'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Storages/StorageFile.cpp:1630: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000015caf8eb 5. /build/src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000148b600e 6. /build/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&) @ 0x00000000148ad029 7. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 8. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 10. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:06:18.958841 [ 16763 ] {b8c1aeb3-3849-4715-9b0e-468994ae480d} 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]:42494). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fc62e75 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fc64467 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x0000000009fb95be 5. /build/src/Server/TCPHandler.cpp:825: DB::TCPHandler::runImpl() @ 0x000000001680727c 6. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:06:19.083201 [ 16758 ] {7f5828e6-491e-4e29-a9c5-30ffa8fb1ced} executeQuery: Code: 43. DB::Exception: Aggregation 'nothingNullMap' is not implemented for mapped arrays. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42480) (comment: 01422_map_skip_null.sql) (query 1, line 1) (in query: select minMap(arrayJoin([([1], [null]), ([1], [null])]));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/AggregateFunctions/Combinators/AggregateFunctionMap.cpp:453: DB::(anonymous namespace)::AggregateFunctionCombinatorMap::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x000000001169e826 5. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:258: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000130cab83 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:06:19.095113 [ 16763 ] {} TCPHandler: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/03250.zJd31u.binary doesn't exist. (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Storages/StorageFile.cpp:1630: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000015caf8eb 5. /build/src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000148b600e 6. /build/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&) @ 0x00000000148ad029 7. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 8. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 10. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:06:19.115090 [ 16758 ] {} TCPHandler: Code: 43. DB::Exception: Aggregation 'nothingNullMap' is not implemented for mapped arrays. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/AggregateFunctions/Combinators/AggregateFunctionMap.cpp:453: DB::(anonymous namespace)::AggregateFunctionCombinatorMap::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x000000001169e826 5. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:258: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000130cab83 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:06:19.308397 [ 16758 ] {e033a56a-130b-422d-93a4-cd4cc79e2629} executeQuery: Code: 43. DB::Exception: Aggregation 'nothingNullMap' is not implemented for mapped arrays. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42480) (comment: 01422_map_skip_null.sql) (query 2, line 2) (in query: select maxMap(arrayJoin([([1], [null]), ([1], [null])]));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/AggregateFunctions/Combinators/AggregateFunctionMap.cpp:453: DB::(anonymous namespace)::AggregateFunctionCombinatorMap::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x000000001169e826 5. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:258: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000130cab83 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:06:19.334028 [ 16758 ] {} TCPHandler: Code: 43. DB::Exception: Aggregation 'nothingNullMap' is not implemented for mapped arrays. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/AggregateFunctions/Combinators/AggregateFunctionMap.cpp:453: DB::(anonymous namespace)::AggregateFunctionCombinatorMap::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x000000001169e826 5. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:258: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000130cab83 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:06:19.674761 [ 16758 ] {4428d88d-d994-4673-8790-999373c6082e} executeQuery: Code: 43. DB::Exception: Aggregation 'nothingNullMap' is not implemented for mapped arrays. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42480) (comment: 01422_map_skip_null.sql) (query 3, line 3) (in query: select sumMap(arrayJoin([([1], [null]), ([1], [null])]));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/AggregateFunctions/Combinators/AggregateFunctionMap.cpp:453: DB::(anonymous namespace)::AggregateFunctionCombinatorMap::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x000000001169e826 5. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:258: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000130cab83 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:06:19.693620 [ 16758 ] {} TCPHandler: Code: 43. DB::Exception: Aggregation 'nothingNullMap' is not implemented for mapped arrays. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/AggregateFunctions/Combinators/AggregateFunctionMap.cpp:453: DB::(anonymous namespace)::AggregateFunctionCombinatorMap::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x000000001169e826 5. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:258: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000130cab83 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:06:19.790956 [ 6637 ] {4db5b8d7-2a54-46d5-ae1d-09db3730af57} executeQuery: Code: 258. DB::Exception: Different number of columns in UNION_ALL elements: c1, c2, c3 and c1, c2. (UNION_ALL_RESULT_STRUCTURES_MISMATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:55666) (comment: 01036_union_different_columns.sql) (query 1, line 1) (in query: select 1 as c1, 2 as c2, 3 as c3 union all (select 1 as c1, 2 as c2, 3 as c3 union all select 1 as c1, 2 as c2) -- { serverError UNION_ALL_RESULT_STRUCTURES_MISMATCH } ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&&) @ 0x000000000e9939cb 4. /build/src/Planner/Utils.cpp:118: DB::buildCommonHeaderForUnion(std::vector> const&, DB::SelectUnionMode) @ 0x0000000013f04d2a 5. /build/src/Planner/Planner.cpp:1373: DB::Planner::buildPlanForUnionNode() @ 0x0000000014895b59 6. /build/src/Planner/Planner.cpp:1321: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951f5 7. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 8. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 10. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:06:19.828580 [ 6637 ] {} TCPHandler: Code: 258. DB::Exception: Different number of columns in UNION_ALL elements: c1, c2, c3 and c1, c2. (UNION_ALL_RESULT_STRUCTURES_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&&) @ 0x000000000e9939cb 4. /build/src/Planner/Utils.cpp:118: DB::buildCommonHeaderForUnion(std::vector> const&, DB::SelectUnionMode) @ 0x0000000013f04d2a 5. /build/src/Planner/Planner.cpp:1373: DB::Planner::buildPlanForUnionNode() @ 0x0000000014895b59 6. /build/src/Planner/Planner.cpp:1321: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951f5 7. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 8. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 10. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:06:20.091556 [ 16758 ] {7d6735d8-cda2-495b-a094-a3dc72ef4604} executeQuery: Code: 43. DB::Exception: Values for -Map cannot be summed, passed type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42480) (comment: 01422_map_skip_null.sql) (query 4, line 4) (in query: select sumMapWithOverflow(arrayJoin([([1], [null]), ([1], [null])]));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/AggregateFunctions/AggregateFunctionSumMap.cpp:130: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:se190107] (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*) @ 0x0000000010d831b8 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130caa1d 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:06:20.114055 [ 16758 ] {} TCPHandler: Code: 43. DB::Exception: Values for -Map cannot be summed, passed type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/AggregateFunctions/AggregateFunctionSumMap.cpp:130: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:se190107] (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*) @ 0x0000000010d831b8 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130caa1d 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:06:20.415883 [ 3834 ] {} DNSResolver: Cannot resolve host (localhos), error 0: Host not found. 2025.07.13 02:06:22.923692 [ 4871 ] {b9cddc85-40a1-45d9-a04f-ff18f54aa1bb} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(quantile, UInt8) of argument for aggregate function sum: In scope SELECT toTypeName(initializeAggregation('sumState', initializeAggregation('quantileState', 0))). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:55678) (comment: 01890_state_of_state.sql) (query 10, line 10) (in query: SELECT toTypeName(initializeAggregation('sumState', initializeAggregation('quantileState', 0)));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a59c08b 4. /build/src/AggregateFunctions/AggregateFunctionSum.cpp:66: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionSum(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000010ce5db7 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130caa1d 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 7. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:253: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000130ca98b 8. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 9. /build/src/Functions/initializeAggregation.cpp:88: DB::(anonymous namespace)::FunctionInitializeAggregation::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c19298c 10. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 11. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 12. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:06:22.941017 [ 4871 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(quantile, UInt8) of argument for aggregate function sum: In scope SELECT toTypeName(initializeAggregation('sumState', initializeAggregation('quantileState', 0))). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a59c08b 4. /build/src/AggregateFunctions/AggregateFunctionSum.cpp:66: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionSum(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000010ce5db7 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130caa1d 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 7. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:253: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000130ca98b 8. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 9. /build/src/Functions/initializeAggregation.cpp:88: DB::(anonymous namespace)::FunctionInitializeAggregation::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c19298c 10. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 11. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 12. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:06:23.037040 [ 16763 ] {8bcc712b-1115-482a-aced-72168bef5067} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=850, jobs=791). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:55716) (comment: 00688_low_cardinality_in.sql) (query 6, line 6) (in query: select val, val in (1, 3) from lc_00688;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbdd1d3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd751c 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 9. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 10. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:06:23.066131 [ 16763 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=850, jobs=791). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbdd1d3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd751c 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 9. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 10. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:06:24.753128 [ 4871 ] {d47f9034-cdc7-4127-95ff-8b66c2b4813d} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(uniq, UInt8) of argument of aggregate function max because the values of that data type are not comparable: In scope SELECT hex(toString(initializeAggregation('maxState', initializeAggregation('uniqState', 0)))). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:55678) (comment: 01890_state_of_state.sql) (query 17, line 17) (in query: SELECT hex(toString(initializeAggregation('maxState', initializeAggregation('uniqState', 0))));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/AggregateFunctions/AggregateFunctionsMinMax.cpp:33: DB::IAggregateFunction* DB::createAggregateFunctionSingleValue(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000108f0782 5. /build/src/AggregateFunctions/AggregateFunctionsMinMax.cpp:200: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMinMax(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000108d2709 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130caa1d 7. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 8. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:253: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000130ca98b 9. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 10. /build/src/Functions/initializeAggregation.cpp:88: DB::(anonymous namespace)::FunctionInitializeAggregation::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c19298c 11. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 12. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 13. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 26. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 27. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 31. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 2025.07.13 02:06:24.767927 [ 4871 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(uniq, UInt8) of argument of aggregate function max because the values of that data type are not comparable: In scope SELECT hex(toString(initializeAggregation('maxState', initializeAggregation('uniqState', 0)))). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/AggregateFunctions/AggregateFunctionsMinMax.cpp:33: DB::IAggregateFunction* DB::createAggregateFunctionSingleValue(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000108f0782 5. /build/src/AggregateFunctions/AggregateFunctionsMinMax.cpp:200: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMinMax(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000108d2709 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130caa1d 7. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 8. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:253: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000130ca98b 9. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 10. /build/src/Functions/initializeAggregation.cpp:88: DB::(anonymous namespace)::FunctionInitializeAggregation::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c19298c 11. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 12. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 13. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 26. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 27. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 31. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 2025.07.13 02:06:25.455142 [ 4871 ] {75ca0d23-6b47-419f-b8d6-4a0ba449d92d} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(uniq, UInt64) of argument for aggregate function quantile. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:55678) (comment: 01890_state_of_state.sql) (query 20, line 20) (in query: SELECT toTypeName(quantileState(x)) FROM (SELECT uniqState(number) AS x FROM numbers(1000));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a59c08b 4. /build/src/AggregateFunctions/AggregateFunctionQuantile.cpp:144: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionQuantile(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000010229191 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130caa1d 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 7. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:253: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000130ca98b 8. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:06:25.484565 [ 4871 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(uniq, UInt64) of argument for aggregate function quantile. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a59c08b 4. /build/src/AggregateFunctions/AggregateFunctionQuantile.cpp:144: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionQuantile(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000010229191 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130caa1d 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 7. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:253: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000130ca98b 8. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:06:25.971705 [ 4871 ] {c65c7395-4437-4b08-b928-0fb44a3c9bc5} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(uniq, UInt64) of argument for aggregate function quantile. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:55678) (comment: 01890_state_of_state.sql) (query 21, line 21) (in query: SELECT hex(toString(quantileState(x))) FROM (SELECT uniqState(number) AS x FROM numbers(1000));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a59c08b 4. /build/src/AggregateFunctions/AggregateFunctionQuantile.cpp:144: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionQuantile(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000010229191 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130caa1d 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 7. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:253: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000130ca98b 8. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 29. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 30. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 2025.07.13 02:06:25.986107 [ 4871 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(uniq, UInt64) of argument for aggregate function quantile. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a59c08b 4. /build/src/AggregateFunctions/AggregateFunctionQuantile.cpp:144: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionQuantile(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000010229191 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130caa1d 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 7. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:253: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000130ca98b 8. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 29. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 30. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 2025.07.13 02:06:28.747256 [ 4896 ] {90ed21b4-0e00-4391-9d93-c65c09476d13} executeQuery: Code: 159. DB::Exception: Timeout exceeded (180 s) while flushing system log 'DB::SystemLogQueue'. (TIMEOUT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43756) (comment: 03203_system_query_metric_log.sh) (query 1, line 1) (in query: SYSTEM FLUSH LOGS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Common/SystemLogBase.cpp:168: DB::SystemLogQueue::waitFlush(long, bool) @ 0x000000000fbee407 5. /build/src/Interpreters/SystemLog.cpp:437: DB::SystemLogs::flush(bool, std::vector> const&) @ 0x0000000014a1ea9f 6. /build/src/Interpreters/InterpreterSystemQuery.cpp:796: DB::InterpreterSystemQuery::execute() @ 0x0000000014bd5a4e 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:06:28.768172 [ 4896 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded (180 s) while flushing system log 'DB::SystemLogQueue'. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Common/SystemLogBase.cpp:168: DB::SystemLogQueue::waitFlush(long, bool) @ 0x000000000fbee407 5. /build/src/Interpreters/SystemLog.cpp:437: DB::SystemLogs::flush(bool, std::vector> const&) @ 0x0000000014a1ea9f 6. /build/src/Interpreters/InterpreterSystemQuery.cpp:796: DB::InterpreterSystemQuery::execute() @ 0x0000000014bd5a4e 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:06:28.781232 [ 4930 ] {582566f0-8e52-4e58-99c7-9d57f9def6b3} 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]:55728) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000011fa678b 4. /build/src/Functions/IFunction.cpp:539: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000012c80d4d 5. /build/src/Functions/IFunction.cpp:593: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c81533 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:06:28.799377 [ 4930 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000011fa678b 4. /build/src/Functions/IFunction.cpp:539: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000012c80d4d 5. /build/src/Functions/IFunction.cpp:593: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c81533 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:06:28.929562 [ 4930 ] {63f67b70-75f9-4424-8828-53746e8fb088} 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]:55728) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000011fa678b 4. /build/src/Functions/IFunction.cpp:539: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000012c80d4d 5. /build/src/Functions/IFunction.cpp:593: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c81533 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:06:28.968384 [ 4930 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000011fa678b 4. /build/src/Functions/IFunction.cpp:539: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000012c80d4d 5. /build/src/Functions/IFunction.cpp:593: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c81533 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:06:29.319290 [ 4930 ] {04d3ebdc-ebda-40f2-91e8-3c4a065ca069} 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]:55728) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/parseReadableSize.cpp:71: DB::FunctionParseReadable::getReturnTypeImpl(std::vector> const&) const @ 0x000000000dda0605 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:06:29.327597 [ 4930 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/parseReadableSize.cpp:71: DB::FunctionParseReadable::getReturnTypeImpl(std::vector> const&) const @ 0x000000000dda0605 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:06:29.733885 [ 4930 ] {ebef71e0-47dd-4520-961f-cbd45c9efae7} 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]:55728) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type>, String&&, std::basic_string_view> const&) @ 0x000000000a06154b 4. /build/src/Functions/parseReadableSize.cpp:168: DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000000dda0eb2 5. /build/src/Functions/parseReadableSize.cpp:106: DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dda0254 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:06:29.751011 [ 4930 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type>, String&&, std::basic_string_view> const&) @ 0x000000000a06154b 4. /build/src/Functions/parseReadableSize.cpp:168: DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000000dda0eb2 5. /build/src/Functions/parseReadableSize.cpp:106: DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dda0254 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:06:30.006186 [ 4930 ] {5addd7a9-e91b-4569-86e9-18023b52fa88} 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]:55728) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000b1f7c4b 4. /build/src/Functions/parseReadableSize.cpp:194: DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000000dda109a 5. /build/src/Functions/parseReadableSize.cpp:106: DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dda0254 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:06:30.042677 [ 4930 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000b1f7c4b 4. /build/src/Functions/parseReadableSize.cpp:194: DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000000dda109a 5. /build/src/Functions/parseReadableSize.cpp:106: DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dda0254 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:06:30.360029 [ 4930 ] {b682f9fd-589c-4e09-92c0-c14128b74bc2} 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]:55728) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type>, String&&, std::basic_string_view> const&) @ 0x000000000a06154b 4. /build/src/Functions/parseReadableSize.cpp:157: DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000000dda0e12 5. /build/src/Functions/parseReadableSize.cpp:106: DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dda0254 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:06:30.388846 [ 4930 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type>, String&&, std::basic_string_view> const&) @ 0x000000000a06154b 4. /build/src/Functions/parseReadableSize.cpp:157: DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000000dda0e12 5. /build/src/Functions/parseReadableSize.cpp:106: DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dda0254 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:06:30.636046 [ 16757 ] {c5dc59d2-ef6a-434a-9ea7-c03b61c9b220} 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]:55756) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Interpreters/ActionsDAG.cpp:1282: DB::ActionsDAG::appendInputsForUnusedColumns(DB::Block const&) @ 0x0000000013ec653f 5. /build/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_ @ 0x00000000148beb4f 6. /build/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&) @ 0x00000000148bc373 7. /build/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&) @ 0x00000000148adbec 8. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 9. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:06:30.659134 [ 16757 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Interpreters/ActionsDAG.cpp:1282: DB::ActionsDAG::appendInputsForUnusedColumns(DB::Block const&) @ 0x0000000013ec653f 5. /build/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_ @ 0x00000000148beb4f 6. /build/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&) @ 0x00000000148bc373 7. /build/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&) @ 0x00000000148adbec 8. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 9. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:06:30.660091 [ 4930 ] {8ef020f0-639e-464d-b40f-bb5cd380c9ba} 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]:55728) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type>, String&&, std::basic_string_view> const&) @ 0x000000000a06154b 4. /build/src/Functions/parseReadableSize.cpp:203: DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000000dda0afb 5. /build/src/Functions/parseReadableSize.cpp:106: DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dda0254 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:06:30.682714 [ 4930 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type>, String&&, std::basic_string_view> const&) @ 0x000000000a06154b 4. /build/src/Functions/parseReadableSize.cpp:203: DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000000dda0afb 5. /build/src/Functions/parseReadableSize.cpp:106: DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dda0254 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:06:30.900670 [ 4930 ] {bee6cf43-fdaf-47a0-b544-d0f6de611ff9} 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]:55728) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000000dda13cb 4. /build/src/Functions/parseReadableSize.cpp:182: DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000000dda0ff6 5. /build/src/Functions/parseReadableSize.cpp:106: DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dda0254 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:06:30.919772 [ 4930 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000000dda13cb 4. /build/src/Functions/parseReadableSize.cpp:182: DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000000dda0ff6 5. /build/src/Functions/parseReadableSize.cpp:106: DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dda0254 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:06:31.082482 [ 4930 ] {011c3542-1202-4794-8a86-7c7031ead2f9} 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]:55728) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000000dda13cb 4. /build/src/Functions/parseReadableSize.cpp:216: DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000000dda113e 5. /build/src/Functions/parseReadableSize.cpp:106: DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dda0254 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:06:31.093597 [ 4930 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000000dda13cb 4. /build/src/Functions/parseReadableSize.cpp:216: DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000000dda113e 5. /build/src/Functions/parseReadableSize.cpp:106: DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dda0254 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:06:31.238723 [ 4930 ] {bf5b2a39-9298-4379-9d67-1ea2d34535c5} 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]:55728) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000b1f7c4b 4. /build/src/Functions/parseReadableSize.cpp:194: DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000000dda109a 5. /build/src/Functions/parseReadableSize.cpp:106: DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dda0254 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:06:31.258346 [ 4930 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000b1f7c4b 4. /build/src/Functions/parseReadableSize.cpp:194: DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000000dda109a 5. /build/src/Functions/parseReadableSize.cpp:106: DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dda0254 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:06:31.438600 [ 4930 ] {c795b238-f032-4b48-8da6-c4e8a37ece25} 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]:55728) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000000dda13cb 4. /build/src/Functions/parseReadableSize.cpp:177: DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000000dda0f54 5. /build/src/Functions/parseReadableSize.cpp:106: DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dda0254 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:06:31.457514 [ 4930 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000000dda13cb 4. /build/src/Functions/parseReadableSize.cpp:177: DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000000dda0f54 5. /build/src/Functions/parseReadableSize.cpp:106: DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dda0254 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:06:31.595082 [ 4930 ] {efac6621-6ca8-48aa-85ea-10e888678652} 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]:55728) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000000dda13cb 4. /build/src/Functions/parseReadableSize.cpp:177: DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000000dda0f54 5. /build/src/Functions/parseReadableSize.cpp:106: DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dda0254 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:06:31.607355 [ 4930 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000000dda13cb 4. /build/src/Functions/parseReadableSize.cpp:177: DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000000dda0f54 5. /build/src/Functions/parseReadableSize.cpp:106: DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dda0254 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:06:31.789936 [ 4930 ] {e352171f-4f2b-421f-9126-6d45328e3eb2} 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]:55728) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000000dda13cb 4. /build/src/Functions/parseReadableSize.cpp:177: DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000000dda0f54 5. /build/src/Functions/parseReadableSize.cpp:106: DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dda0254 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:06:31.813251 [ 4930 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000000dda13cb 4. /build/src/Functions/parseReadableSize.cpp:177: DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000000dda0f54 5. /build/src/Functions/parseReadableSize.cpp:106: DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dda0254 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:06:32.127215 [ 4930 ] {e4b3f783-5608-4d7a-852f-7abef1ca7fe1} 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]:55728) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000000dda13cb 4. /build/src/Functions/parseReadableSize.cpp:177: DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000000dda0f54 5. /build/src/Functions/parseReadableSize.cpp:106: DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dda0254 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:06:32.137903 [ 4930 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000000dda13cb 4. /build/src/Functions/parseReadableSize.cpp:177: DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000000dda0f54 5. /build/src/Functions/parseReadableSize.cpp:106: DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dda0254 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:06:32.274270 [ 4930 ] {fef84c05-6bd0-4eb3-8ddc-23075e07f004} 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]:55728) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000000dda13cb 4. /build/src/Functions/parseReadableSize.cpp:177: DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000000dda0f54 5. /build/src/Functions/parseReadableSize.cpp:106: DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dda0254 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:06:32.315335 [ 4930 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000000dda13cb 4. /build/src/Functions/parseReadableSize.cpp:177: DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000000dda0f54 5. /build/src/Functions/parseReadableSize.cpp:106: DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dda0254 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:06:32.460143 [ 4930 ] {005f0def-95e2-40f9-9e87-229beb032d80} 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]:55728) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000000dda13cb 4. /build/src/Functions/parseReadableSize.cpp:177: DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000000dda0f54 5. /build/src/Functions/parseReadableSize.cpp:106: DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dda0254 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:06:32.488809 [ 4930 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000000dda13cb 4. /build/src/Functions/parseReadableSize.cpp:177: DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000000dda0f54 5. /build/src/Functions/parseReadableSize.cpp:106: DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dda0254 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:06:32.648309 [ 4930 ] {0c35f554-f922-4d0a-a583-2266e355cd5e} 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]:55728) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000000dda13cb 4. /build/src/Functions/parseReadableSize.cpp:177: DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000000dda0f54 5. /build/src/Functions/parseReadableSize.cpp:106: DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dda0254 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:06:32.660070 [ 4930 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000000dda13cb 4. /build/src/Functions/parseReadableSize.cpp:177: DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000000dda0f54 5. /build/src/Functions/parseReadableSize.cpp:106: DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dda0254 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:06:32.763086 [ 4930 ] {a5c355e7-c56c-4666-b16b-d9e3f5643eca} 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]:55728) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000000dda13cb 4. /build/src/Functions/parseReadableSize.cpp:177: DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000000dda0f54 5. /build/src/Functions/parseReadableSize.cpp:106: DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dda0254 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:06:32.779298 [ 4930 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000000dda13cb 4. /build/src/Functions/parseReadableSize.cpp:177: DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000000dda0f54 5. /build/src/Functions/parseReadableSize.cpp:106: DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dda0254 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:06:32.887298 [ 4930 ] {50181a1f-afbf-46f2-85f3-0317bec500d3} 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]:55728) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000000dda13cb 4. /build/src/Functions/parseReadableSize.cpp:177: DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000000dda0f54 5. /build/src/Functions/parseReadableSize.cpp:106: DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dda0254 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:06:32.988243 [ 4930 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000000dda13cb 4. /build/src/Functions/parseReadableSize.cpp:177: DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000000dda0f54 5. /build/src/Functions/parseReadableSize.cpp:106: DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dda0254 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:06:33.011304 [ 5018 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 109231.016902 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, unsigned long const&) @ 0x00000000144421ab 4. /build/src/Interpreters/ProcessList.cpp:519: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000001496a7fb 5. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x000000001496af0d 6. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000168d1a5a 7. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0c24 8. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168cfe81 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x00000000168cf907 5. /build/src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000001680710e 6. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 2025.07.13 02:06:33.106063 [ 4930 ] {c5dda09c-dd45-456f-ae80-f7603660231c} 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]:55728) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000000dda13cb 4. /build/src/Functions/parseReadableSize.cpp:177: DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000000dda0f54 5. /build/src/Functions/parseReadableSize.cpp:106: DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dda0254 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:06:33.118302 [ 4930 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000000dda13cb 4. /build/src/Functions/parseReadableSize.cpp:177: DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000000dda0f54 5. /build/src/Functions/parseReadableSize.cpp:106: DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dda0254 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:06:33.213309 [ 4930 ] {5da3b5d4-7aed-4d34-ab26-8660d3b3e30f} 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]:55728) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000000dda13cb 4. /build/src/Functions/parseReadableSize.cpp:177: DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000000dda0f54 5. /build/src/Functions/parseReadableSize.cpp:106: DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dda0254 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:06:33.238985 [ 4930 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000000dda13cb 4. /build/src/Functions/parseReadableSize.cpp:177: DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000000dda0f54 5. /build/src/Functions/parseReadableSize.cpp:106: DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dda0254 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:06:33.393611 [ 4930 ] {9a473c09-fa83-4ced-8b2e-9e4489a53b48} 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]:55728) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000000dda13cb 4. /build/src/Functions/parseReadableSize.cpp:177: DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000000dda0f54 5. /build/src/Functions/parseReadableSize.cpp:106: DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dda0254 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:06:33.404004 [ 4930 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, double&) @ 0x000000000dda13cb 4. /build/src/Functions/parseReadableSize.cpp:177: DB::FunctionParseReadable::parseReadableFormat(std::basic_string_view> const&) const @ 0x000000000dda0f54 5. /build/src/Functions/parseReadableSize.cpp:106: DB::FunctionParseReadable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dda0254 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:06:40.015170 [ 6615 ] {b129ffed-439e-4cfd-9f5c-349c37bb6a5b} 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]:46880) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, int&&, String&&) @ 0x000000000b96964b 4. /build/src/Functions/h3kRing.cpp:56: DB::(anonymous namespace)::FunctionH3KRing::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000c14c897 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:06:40.078032 [ 6615 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, int&&, String&&) @ 0x000000000b96964b 4. /build/src/Functions/h3kRing.cpp:56: DB::(anonymous namespace)::FunctionH3KRing::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000c14c897 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:06:40.333862 [ 6615 ] {1bd5e59a-f348-49d3-b7ee-37754e374255} 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]:46880) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int const&) @ 0x000000000c13b30b 4. /build/src/Functions/h3kRing.cpp:112: DB::(anonymous namespace)::FunctionH3KRing::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c14c1d1 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:06:40.348781 [ 6615 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int const&) @ 0x000000000c13b30b 4. /build/src/Functions/h3kRing.cpp:112: DB::(anonymous namespace)::FunctionH3KRing::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c14c1d1 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:06:40.805679 [ 6615 ] {3de629b6-37d8-4bfb-9386-12427aad8ef9} 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]:46880) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, int&&, String&&) @ 0x000000000b96964b 4. /build/src/Functions/h3kRing.cpp:56: DB::(anonymous namespace)::FunctionH3KRing::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000c14c897 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:06:40.813887 [ 6615 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, int&&, String&&) @ 0x000000000b96964b 4. /build/src/Functions/h3kRing.cpp:56: DB::(anonymous namespace)::FunctionH3KRing::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000c14c897 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:06:42.183585 [ 16757 ] {9302f60a-fb03-492a-8ee4-ca9e64f361f6} 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]:55756) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/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 @ 0x0000000014916540 5. /build/src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x000000001491636a 6. /build/src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000014ca12b1 7. /build/src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000016b35885 8. /build/src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x0000000016d03ae4 9. /build/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) @ 0x0000000016d0186d 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, 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&&) @ 0x00000000148cff60 11. /build/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&) @ 0x00000000148bfc49 12. /build/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&) @ 0x00000000148bd384 13. /build/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&) @ 0x00000000148adbec 14. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 15. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 17. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 19. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 20. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 2025.07.13 02:06:42.188150 [ 16757 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/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 @ 0x0000000014916540 5. /build/src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x000000001491636a 6. /build/src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000014ca12b1 7. /build/src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000016b35885 8. /build/src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x0000000016d03ae4 9. /build/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) @ 0x0000000016d0186d 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, 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&&) @ 0x00000000148cff60 11. /build/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&) @ 0x00000000148bfc49 12. /build/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&) @ 0x00000000148bd384 13. /build/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&) @ 0x00000000148adbec 14. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 15. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 17. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 19. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 20. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 2025.07.13 02:06:44.789047 [ 16757 ] {f8a0e08c-f74a-4183-9b58-7e487b8d8d54} 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]:55756) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/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 @ 0x0000000014916540 5. /build/src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x000000001491636a 6. /build/src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000014ca12b1 7. /build/src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000016b35885 8. /build/src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x0000000016d03ae4 9. /build/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) @ 0x0000000016d0186d 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, 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&&) @ 0x00000000148cff60 11. /build/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&) @ 0x00000000148bfc49 12. /build/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&) @ 0x00000000148bd384 13. /build/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&) @ 0x00000000148adbec 14. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 15. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 17. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 19. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 20. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 2025.07.13 02:06:44.801573 [ 16757 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/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 @ 0x0000000014916540 5. /build/src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x000000001491636a 6. /build/src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000014ca12b1 7. /build/src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000016b35885 8. /build/src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x0000000016d03ae4 9. /build/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) @ 0x0000000016d0186d 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, 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&&) @ 0x00000000148cff60 11. /build/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&) @ 0x00000000148bfc49 12. /build/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&) @ 0x00000000148bd384 13. /build/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&) @ 0x00000000148adbec 14. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 15. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 17. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 19. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 20. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 2025.07.13 02:06:44.939619 [ 6166 ] {a1612231-b25d-4610-b02f-b0cdb4c09949} 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]:46922) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000009fd7e2b 4. /build/src/Functions/runningDifference.h:148: DB::FunctionRunningDifferenceImpl::create(std::shared_ptr) @ 0x000000000e577bc4 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012c8d35f 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012c8cc13 7. /build/src/Functions/FunctionFactory.cpp:151: DB::FunctionFactory::tryGet(String const&, std::shared_ptr) const @ 0x0000000012c8d1c1 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3313: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52c63 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:06:44.975169 [ 6166 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000009fd7e2b 4. /build/src/Functions/runningDifference.h:148: DB::FunctionRunningDifferenceImpl::create(std::shared_ptr) @ 0x000000000e577bc4 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012c8d35f 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012c8cc13 7. /build/src/Functions/FunctionFactory.cpp:151: DB::FunctionFactory::tryGet(String const&, std::shared_ptr) const @ 0x0000000012c8d1c1 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3313: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52c63 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:06:45.146233 [ 6166 ] {b942e6dd-8961-424b-b4a4-f4c487cff7eb} 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]:46922) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000009fd7e2b 4. /build/src/Functions/runningDifference.h:148: DB::FunctionRunningDifferenceImpl::create(std::shared_ptr) @ 0x000000000e577bc4 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012c8d35f 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012c8cc13 7. /build/src/Functions/FunctionFactory.cpp:151: DB::FunctionFactory::tryGet(String const&, std::shared_ptr) const @ 0x0000000012c8d1c1 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3313: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52c63 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:06:45.171306 [ 6166 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000009fd7e2b 4. /build/src/Functions/runningDifference.h:148: DB::FunctionRunningDifferenceImpl::create(std::shared_ptr) @ 0x000000000e577bc4 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012c8d35f 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012c8cc13 7. /build/src/Functions/FunctionFactory.cpp:151: DB::FunctionFactory::tryGet(String const&, std::shared_ptr) const @ 0x0000000012c8d1c1 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3313: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52c63 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:06:45.175465 [ 16757 ] {335e5fa4-7a3d-43c7-8695-59195df83333} 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]:55756) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/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 @ 0x0000000014916540 5. /build/src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000014ca12b1 6. /build/src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000016b35885 7. /build/src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x0000000016d03ae4 8. /build/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) @ 0x0000000016d0186d 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, 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&&) @ 0x00000000148cff60 10. /build/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&) @ 0x00000000148bfc49 11. /build/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&) @ 0x00000000148bd384 12. /build/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&) @ 0x00000000148adbec 13. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 14. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:06:45.196346 [ 16757 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/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 @ 0x0000000014916540 5. /build/src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000014ca12b1 6. /build/src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000016b35885 7. /build/src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x0000000016d03ae4 8. /build/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) @ 0x0000000016d0186d 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, 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&&) @ 0x00000000148cff60 10. /build/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&) @ 0x00000000148bfc49 11. /build/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&) @ 0x00000000148bd384 12. /build/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&) @ 0x00000000148adbec 13. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 14. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:06:45.285315 [ 6166 ] {57fe9fbb-9769-43c7-af10-d65ff39ce24f} 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]:46922) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000009fd7e2b 4. /build/src/Functions/runningDifference.h:148: DB::FunctionRunningDifferenceImpl::create(std::shared_ptr) @ 0x000000000e577bc4 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012c8d35f 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012c8cc13 7. /build/src/Functions/FunctionFactory.cpp:151: DB::FunctionFactory::tryGet(String const&, std::shared_ptr) const @ 0x0000000012c8d1c1 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3313: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52c63 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:06:45.298999 [ 6166 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000009fd7e2b 4. /build/src/Functions/runningDifference.h:148: DB::FunctionRunningDifferenceImpl::create(std::shared_ptr) @ 0x000000000e577bc4 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012c8d35f 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012c8cc13 7. /build/src/Functions/FunctionFactory.cpp:151: DB::FunctionFactory::tryGet(String const&, std::shared_ptr) const @ 0x0000000012c8d1c1 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3313: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52c63 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:06:45.420739 [ 6166 ] {d190cc94-7c89-4d68-961a-567d7c03a81c} 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]:46922) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000009fd7e2b 4. /build/src/Functions/runningDifference.h:148: DB::FunctionRunningDifferenceImpl::create(std::shared_ptr) @ 0x000000000e577bc4 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012c8d35f 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012c8cc13 7. /build/src/Functions/FunctionFactory.cpp:151: DB::FunctionFactory::tryGet(String const&, std::shared_ptr) const @ 0x0000000012c8d1c1 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3313: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52c63 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:06:45.456712 [ 6166 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000009fd7e2b 4. /build/src/Functions/runningDifference.h:148: DB::FunctionRunningDifferenceImpl::create(std::shared_ptr) @ 0x000000000e577bc4 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012c8d35f 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012c8cc13 7. /build/src/Functions/FunctionFactory.cpp:151: DB::FunctionFactory::tryGet(String const&, std::shared_ptr) const @ 0x0000000012c8d1c1 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3313: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52c63 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:06:45.476233 [ 16757 ] {30ea7bc1-89b7-4a29-92e2-a95e9ee8b239} 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]:55756) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/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 @ 0x0000000014916540 5. /build/src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x000000001491636a 6. /build/src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000014ca12b1 7. /build/src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000016b35885 8. /build/src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x0000000016d03ae4 9. /build/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) @ 0x0000000016d0186d 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, 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&&) @ 0x00000000148cff60 11. /build/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&) @ 0x00000000148bfc49 12. /build/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&) @ 0x00000000148bd384 13. /build/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&) @ 0x00000000148adbec 14. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 15. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 17. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 19. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 20. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 2025.07.13 02:06:45.558833 [ 16757 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/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 @ 0x0000000014916540 5. /build/src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x000000001491636a 6. /build/src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000014ca12b1 7. /build/src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000016b35885 8. /build/src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x0000000016d03ae4 9. /build/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) @ 0x0000000016d0186d 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, 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&&) @ 0x00000000148cff60 11. /build/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&) @ 0x00000000148bfc49 12. /build/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&) @ 0x00000000148bd384 13. /build/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&) @ 0x00000000148adbec 14. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 15. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 17. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 19. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 20. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 2025.07.13 02:06:45.697740 [ 16757 ] {efe3f889-4b37-4a6e-8db2-c78a2a01fa43} 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]:55756) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/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 @ 0x0000000014916540 5. /build/src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000014ca12b1 6. /build/src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000016b35885 7. /build/src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x0000000016d03ae4 8. /build/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) @ 0x0000000016d0186d 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, 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&&) @ 0x00000000148cff60 10. /build/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&) @ 0x00000000148bfc49 11. /build/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&) @ 0x00000000148bd384 12. /build/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&) @ 0x00000000148adbec 13. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 14. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:06:45.715769 [ 16757 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/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 @ 0x0000000014916540 5. /build/src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000014ca12b1 6. /build/src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000016b35885 7. /build/src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x0000000016d03ae4 8. /build/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) @ 0x0000000016d0186d 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, 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&&) @ 0x00000000148cff60 10. /build/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&) @ 0x00000000148bfc49 11. /build/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&) @ 0x00000000148bd384 12. /build/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&) @ 0x00000000148adbec 13. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 14. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:06:46.839518 [ 6532 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000013779f8b 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000137794b8 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778bc3 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678d325 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:06:48.104384 [ 16757 ] {c77672dd-79fe-4cae-8ef7-cff1a3144c46} 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]:55756) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000009fbd84b 4. /build/src/Functions/FunctionsLogical.cpp:542: DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000012cb015a 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5148: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f66bff 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:06:48.124516 [ 16757 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000009fbd84b 4. /build/src/Functions/FunctionsLogical.cpp:542: DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000012cb015a 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5148: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f66bff 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:06:48.317858 [ 16757 ] {6bf5ff67-6683-47f7-83b9-e92d8ce9f2c3} 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]:55756) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000009fbd84b 4. /build/src/Functions/FunctionsLogical.cpp:542: DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000012cb015a 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5148: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f66bff 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:06:48.326164 [ 16757 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000009fbd84b 4. /build/src/Functions/FunctionsLogical.cpp:542: DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000012cb015a 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5148: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f66bff 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:06:53.464813 [ 4922 ] {bac398cb-5fb4-42e1-b9fe-3b867802e432} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=2): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:55814) (comment: 02346_additional_filters.sql) (query 58, line 88) (in query: select * from m_table order by x settings additional_table_filters={'m_table' : 'x != 4', 'table_1' : 'x != 2', 'table_2' : 'x != 5'};), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x00000000163993d1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016396620 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001639641f 10. /build/src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000163b2bd7 11. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x00000000162ea22d 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x00000000162e6974 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x00000000163d9d66 14. /build/src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x0000000016d7885f 15. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x0000000016d9cdca 16. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5520 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 18. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 22. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:06:53.523460 [ 4922 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=2): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x00000000163993d1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016396620 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001639641f 10. /build/src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000163b2bd7 11. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x00000000162ea22d 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x00000000162e6974 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x00000000163d9d66 14. /build/src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x0000000016d7885f 15. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x0000000016d9cdca 16. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5520 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 18. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 22. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:06:54.310118 [ 16756 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778c58 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168167bf 10. /build/src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000001680ff45 11. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:06:54.325352 [ 16756 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x0000000016810069 5. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 6. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 2025.07.13 02:06:55.424707 [ 5998 ] {42b1b804-9fa4-4533-a053-84c5f2cb341f} executeQuery: Code: 57. DB::Exception: Table test_bbwirfbu.test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02941_variant_type_2.sh) (in query: /* ddl_entry=query-0000000007 */ CREATE TABLE test_bbwirfbu.test UUID '0626fda1-d725-4552-bf36-f31ddc43f0a5' (`id` UInt64, `v` Variant(Array(UInt64), LowCardinality(String), String, Tuple(a UInt32, b UInt32), UInt64)) ENGINE = MergeTree ORDER BY id SETTINGS min_rows_for_wide_part = 1, min_bytes_for_wide_part = 1, index_granularity_bytes = 10485760, index_granularity = 8192, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 68848272, compact_parts_max_bytes_to_buffer = 387302291, compact_parts_max_granules_to_buffer = 132, compact_parts_merge_max_bytes_to_prefetch_part = 820328, merge_max_block_size = 18830, 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 = 33, min_merge_bytes_to_use_direct_io = 2187808952, 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 = 8499, primary_key_compress_block_size = 82666, use_primary_key_cache = false, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 12. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:06:55.519534 [ 5998 ] {42b1b804-9fa4-4533-a053-84c5f2cb341f} executeQuery: Code: 57. DB::Exception: Table test_bbwirfbu.test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54366) (comment: 02941_variant_type_2.sh) (query 1, line 1) (in query: CREATE TABLE test (`id` UInt64, `v` Variant(String, UInt64, LowCardinality(String), Tuple(a UInt32, b UInt32), Array(UInt64))) ENGINE = MergeTree ORDER BY id SETTINGS min_rows_for_wide_part = 1, min_bytes_for_wide_part = 1, index_granularity_bytes = 10485760, index_granularity = 8192, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 68848272, compact_parts_max_bytes_to_buffer = 387302291, compact_parts_max_granules_to_buffer = 132, compact_parts_merge_max_bytes_to_prefetch_part = 820328, merge_max_block_size = 18830, 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 = 33, min_merge_bytes_to_use_direct_io = 2187808952, 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 = 8499, primary_key_compress_block_size = 82666, use_primary_key_cache = false, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 12. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:06:55.548226 [ 5998 ] {} TCPHandler: Code: 57. DB::Exception: Table test_bbwirfbu.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 12. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:06:56.777965 [ 16763 ] {6fc9efb6-0acb-4cd1-8eb0-edf4ed2803ba} 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]:46898) (comment: 03146_asof_join_ddb_merge_long.gen.sql) (query 6, line 39) (in query: -- TODO: enable once USING and `join_use_nulls` is supported by `full_sorting_merge` -- SET join_use_nulls = 1; WITH build AS ( SELECT tk.number AS k, toDateTime('2021-01-01 00:00:00') + INTERVAL i.number SECONDS AS t, i.number % 37 AS v FROM numbers(3000000) AS i CROSS JOIN numbers(2) AS tk SETTINGS join_algorithm = 'hash', join_use_nulls = 0 ), probe AS ( SELECT tk.number AS k, toDateTime('2021-01-01 00:00:30') + INTERVAL tt.number HOUR AS t FROM numbers(2) AS tk CROSS JOIN numbers(toUInt32((toDateTime('2021-02-01 00:00:30') - toDateTime('2021-01-01 00:00:30')) / 3600)) AS tt SETTINGS join_algorithm = 'hash', join_use_nulls = 0 ) SELECT SUM(v) AS v, COUNT(*) AS n FROM probe ASOF LEFT JOIN build USING (k, t) ;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Planner/PlannerJoins.cpp:1283: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x00000000148e4a3c 5. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0e7d2 6. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 7. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:06:56.834541 [ 16763 ] {} TCPHandler: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Planner/PlannerJoins.cpp:1283: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x00000000148e4a3c 5. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0e7d2 6. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 7. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:06:56.976784 [ 16756 ] {683ff7e5-b153-4011-8855-afca97def3a6} executeQuery: Code: 47. DB::Exception: Unknown identifier 'xyz' inside COLUMNS matcher. In scope Scope node SELECT COLUMNS(bar, foo, xyz) APPLY length() FROM test_5.test Identifier lookup to resolve state 0 Expression resolve process stack size: 1 Expression COLUMNS(bar, foo, xyz) APPLY length Table expression node to data: 1 { test_5.test data: Table expression name 'test_5.test', description 'table' database name 'test_5' table name 'test' Should qualify columns 1 Columns size 12 { _block_offset : COLUMN id: 0, column_name: _block_offset, result_type: UInt64, source_id: 1 } { _block_number : COLUMN id: 0, column_name: _block_number, result_type: UInt64, source_id: 1 } { _part_offset : COLUMN id: 0, column_name: _part_offset, result_type: UInt64, source_id: 1 } { _row_exists : COLUMN id: 0, column_name: _row_exists, result_type: UInt8, source_id: 1 } { _partition_id : COLUMN id: 0, column_name: _partition_id, result_type: LowCardinality(String), source_id: 1 } { _part_uuid : COLUMN id: 0, column_name: _part_uuid, result_type: UUID, source_id: 1 } { _part_index : COLUMN id: 0, column_name: _part_index, result_type: UInt64, source_id: 1 } { _part : COLUMN id: 0, column_name: _part, result_type: LowCardinality(String), source_id: 1 } { _part_data_version : COLUMN id: 0, column_name: _part_data_version, result_type: UInt64, source_id: 1 } { _sample_factor : COLUMN id: 0, column_name: _sample_factor, result_type: Float64, source_id: 1 } { bar : COLUMN id: 0, column_name: bar, result_type: String, source_id: 1 } { foo : COLUMN id: 0, column_name: foo, result_type: String, source_id: 1 } } Registered table expression nodes table size: 1 { '' : test_5.test } Subquery depth 0 . (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54364) (comment: 03152_analyzer_columns_list.sql) (query 4, line 13) (in query: SELECT COLUMNS(bar, foo, xyz) APPLY (length) FROM test;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1971: DB::QueryAnalyzer::resolveUnqualifiedMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f59606 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2206: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5a3c9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3800: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38d68 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 11. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 12. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 17. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 19. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 20. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 2025.07.13 02:06:57.012309 [ 16756 ] {} TCPHandler: Code: 47. DB::Exception: Unknown identifier 'xyz' inside COLUMNS matcher. In scope Scope node SELECT COLUMNS(bar, foo, xyz) APPLY length() FROM test_5.test Identifier lookup to resolve state 0 Expression resolve process stack size: 1 Expression COLUMNS(bar, foo, xyz) APPLY length Table expression node to data: 1 { test_5.test data: Table expression name 'test_5.test', description 'table' database name 'test_5' table name 'test' Should qualify columns 1 Columns size 12 { _block_offset : COLUMN id: 0, column_name: _block_offset, result_type: UInt64, source_id: 1 } { _block_number : COLUMN id: 0, column_name: _block_number, result_type: UInt64, source_id: 1 } { _part_offset : COLUMN id: 0, column_name: _part_offset, result_type: UInt64, source_id: 1 } { _row_exists : COLUMN id: 0, column_name: _row_exists, result_type: UInt8, source_id: 1 } { _partition_id : COLUMN id: 0, column_name: _partition_id, result_type: LowCardinality(String), source_id: 1 } { _part_uuid : COLUMN id: 0, column_name: _part_uuid, result_type: UUID, source_id: 1 } { _part_index : COLUMN id: 0, column_name: _part_index, result_type: UInt64, source_id: 1 } { _part : COLUMN id: 0, column_name: _part, result_type: LowCardinality(String), source_id: 1 } { _part_data_version : COLUMN id: 0, column_name: _part_data_version, result_type: UInt64, source_id: 1 } { _sample_factor : COLUMN id: 0, column_name: _sample_factor, result_type: Float64, source_id: 1 } { bar : COLUMN id: 0, column_name: bar, result_type: String, source_id: 1 } { foo : COLUMN id: 0, column_name: foo, result_type: String, source_id: 1 } } Registered table expression nodes table size: 1 { '' : test_5.test } Subquery depth 0 . (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1971: DB::QueryAnalyzer::resolveUnqualifiedMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f59606 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2206: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5a3c9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3800: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38d68 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 11. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 12. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 17. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 19. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 20. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 2025.07.13 02:06:59.569789 [ 16758 ] {1220d298-c7db-450d-a310-47365ad072b5} 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]:46884) (comment: 00926_adaptive_index_granularity_pk.sql) (query 45, line 92) (in query: DETACH TABLE large_alter_table_00926;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Databases/DatabaseReplicated.cpp:1106: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013cc3688 5. /build/src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc384b 6. /build/src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833287 7. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 8. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 9. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:06:59.580233 [ 16758 ] {} TCPHandler: Code: 80. DB::Exception: DETACH TABLE is not allowed for Replicated databases. Use DETACH TABLE PERMANENTLY or SYSTEM RESTART REPLICA or set database_replicated_always_detach_permanently to 1. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Databases/DatabaseReplicated.cpp:1106: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013cc3688 5. /build/src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc384b 6. /build/src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833287 7. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 8. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 9. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:07:00.046317 [ 16757 ] {0e71ddee-1221-4ab5-a5d8-8cf978887625} 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]:55756) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Interpreters/ActionsDAG.cpp:1282: DB::ActionsDAG::appendInputsForUnusedColumns(DB::Block const&) @ 0x0000000013ec653f 5. /build/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_ @ 0x00000000148beb4f 6. /build/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&) @ 0x00000000148bc373 7. /build/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&) @ 0x00000000148adbec 8. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 9. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:07:00.061896 [ 16757 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Interpreters/ActionsDAG.cpp:1282: DB::ActionsDAG::appendInputsForUnusedColumns(DB::Block const&) @ 0x0000000013ec653f 5. /build/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_ @ 0x00000000148beb4f 6. /build/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&) @ 0x00000000148bc373 7. /build/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&) @ 0x00000000148adbec 8. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 9. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:07:00.401488 [ 6166 ] {d04623f8-d039-4d6c-b96e-4fe89a44207b} 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]:46922) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/tupleElement.cpp:63: DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e84c9c4 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:07:00.411174 [ 6166 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/tupleElement.cpp:63: DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e84c9c4 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:07:01.204784 [ 6168 ] {0e1a477d-f966-413e-944c-3690f79b62bc} 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]:55270) (comment: 02317_distinct_in_order_optimization.sql) (query 66, line 81) (in query: CREATE TABLE ordinary_distinct (`low` UInt64, `medium` UInt64, `high` UInt64) ENGINE = MergeTree ORDER BY (low, medium) SETTINGS index_granularity = 8192, 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 = 66, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 406171858, compact_parts_max_granules_to_buffer = 241, compact_parts_merge_max_bytes_to_prefetch_part = 27098908, merge_max_block_size = 19974, old_parts_lifetime = 290., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 36, 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 = 59014, primary_key_compress_block_size = 89558, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda7a6 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000118cbf6e 8. /build/src/Storages/MergeTree/MergeTreeData.cpp:1922: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x0000000016238b3d 9. /build/src/Storages/StorageMergeTree.cpp:161: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000016556df5 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000165568d0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000165531fd 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ca1a22 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001481ee32 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:07:01.241770 [ 6168 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda7a6 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000118cbf6e 8. /build/src/Storages/MergeTree/MergeTreeData.cpp:1922: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x0000000016238b3d 9. /build/src/Storages/StorageMergeTree.cpp:161: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000016556df5 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000165568d0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000165531fd 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ca1a22 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001481ee32 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:07:02.104107 [ 6166 ] {38e666ec-c717-4054-9958-23cd31ebbba7} 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]:46922) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000009fbd84b 4. /build/src/Functions/FunctionsLogical.cpp:542: DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000012cac83a 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:07:02.168050 [ 6166 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000009fbd84b 4. /build/src/Functions/FunctionsLogical.cpp:542: DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000012cac83a 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:07:02.327129 [ 6166 ] {5aad8b0e-3906-4768-9167-14598ae07a3e} 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]:46922) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000009fbd84b 4. /build/src/Functions/FunctionsLogical.cpp:542: DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000012cac83a 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:07:02.347700 [ 6166 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000009fbd84b 4. /build/src/Functions/FunctionsLogical.cpp:542: DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000012cac83a 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:07:02.518631 [ 6166 ] {0c9cdbd1-2d3b-4d8c-9be1-c43fdeaf34ba} 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]:46922) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000009fbd84b 4. /build/src/Functions/FunctionsLogical.cpp:542: DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000012cac83a 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:07:02.533271 [ 6166 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000009fbd84b 4. /build/src/Functions/FunctionsLogical.cpp:542: DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000012cac83a 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:07:02.856586 [ 6166 ] {5f994d2a-52a9-4251-a00e-33e1b7113562} 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]:46922) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000009fbd84b 4. /build/src/Functions/FunctionsLogical.cpp:542: DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000012cac83a 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:07:02.880595 [ 6166 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000009fbd84b 4. /build/src/Functions/FunctionsLogical.cpp:542: DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000012cac83a 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:07:02.958269 [ 16757 ] {0ff5dfe2-b97d-4565-9716-d9a8bfbb41e4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:55756) (comment: 01881_join_on_conditions_hash.gen.sql) (query 99, line 123) (in query: SELECT '333' = t1.key FROM t1 INNER ANY JOIN t2_lc as t2 ON t1.id == t2.id AND t2.key == t2.key2 AND t1.key == t1.key2 AND t1.key2 == '333';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x00000000163993d1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016396620 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001639641f 10. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000163ced63 11. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000163cffce 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013b9f869 13. /build/src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000013b9fb5d 14. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000163ccfc4 15. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:59: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000163ccdcc 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x00000000162f3280 17. /build/src/Storages/MergeTree/MergeTreeDataPartWide.cpp:52: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x00000000162ee6be 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x00000000163d9d66 19. /build/src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x0000000016d7885f 20. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x0000000016d9cdca 21. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5520 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 23. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 25. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 26. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 27. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 28. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 29. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 31. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 2025.07.13 02:07:02.980627 [ 16757 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x00000000163993d1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016396620 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001639641f 10. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000163ced63 11. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000163cffce 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013b9f869 13. /build/src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000013b9fb5d 14. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000163ccfc4 15. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:59: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000163ccdcc 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x00000000162f3280 17. /build/src/Storages/MergeTree/MergeTreeDataPartWide.cpp:52: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x00000000162ee6be 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x00000000163d9d66 19. /build/src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x0000000016d7885f 20. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x0000000016d9cdca 21. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5520 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 23. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 25. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 26. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 27. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 28. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 29. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 31. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:07:03.024692 [ 6166 ] {efa9d857-608c-44b2-a753-e9339065dc88} 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]:46922) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000009fbd84b 4. /build/src/Functions/FunctionsLogical.cpp:542: DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000012cac83a 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:07:03.051662 [ 6166 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000009fbd84b 4. /build/src/Functions/FunctionsLogical.cpp:542: DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000012cac83a 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:07:03.188589 [ 6166 ] {98e0789c-9c49-4e2f-bbf2-a012a6bfa3e7} 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]:46922) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000009fbd84b 4. /build/src/Functions/FunctionsLogical.cpp:542: DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000012cac83a 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:07:03.223034 [ 6166 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000009fbd84b 4. /build/src/Functions/FunctionsLogical.cpp:542: DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000012cac83a 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:07:03.498302 [ 3542 ] {b8bb78dc-2238-4c0d-9c9e-c273bf62cc75} 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]:48866) (comment: 01881_join_on_conditions_hash.gen.sql) (in query: DROP DATABASE IF EXISTS test_lfio0jo9 SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:07:03.503755 [ 3542 ] {b8bb78dc-2238-4c0d-9c9e-c273bf62cc75} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:07:03.810391 [ 4870 ] {} HTTPServerRequest: Got an HTTP request with no content length and no chunked/multipart encoding, it may be impossible to distinguish graceful EOF from abnormal connection loss 2025.07.13 02:07:03.868776 [ 4870 ] {} DynamicQueryHandler: Code: 381. DB::Exception: The Transfer-Encoding is not chunked and there is no Content-Length header for POST request. (HTTP_LENGTH_REQUIRED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Server/HTTPHandler.cpp:748: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167912b1 5. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 6. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 7. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 8. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 9. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:07:03.983239 [ 4870 ] {} 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]:46360). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fc62e75 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fc64467 4. /build/src/Server/HTTP/HTTPServerResponse.h:197: DB::HTTPWriteBuffer::nextImplChunked() @ 0x000000001682f8f4 5. /build/src/Server/HTTP/HTTPServerResponse.h:166: DB::WriteBufferFromHTTPServerResponse::nextImpl() @ 0x000000001682d8f4 6. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x0000000009fb95be 7. /build/src/IO/WriteBuffer.h:127: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x000000001682dfff 8. /build/src/IO/WriteBuffer.cpp:95: DB::WriteBuffer::finalize() @ 0x000000000fb98f30 9. /build/src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:283: DB::WriteBufferFromHTTPServerResponse::cancelWithException(DB::HTTPServerRequest&, int, String const&, DB::WriteBuffer*) @ 0x000000001682e55a 10. /build/src/Server/HTTPHandler.cpp:624: DB::HTTPHandler::trySendExceptionToClient(int, String const&, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x000000001678f8ae 11. /build/src/Server/HTTPHandler.cpp:771: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016791c23 12. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:07:05.569627 [ 6166 ] {c3f9aafb-1cc4-44a1-9537-7efe5f62d4c3} 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]:46922) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/toFixedString.h:50: DB::FunctionToFixedString::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e766dfb 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:07:05.603085 [ 6166 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/toFixedString.h:50: DB::FunctionToFixedString::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e766dfb 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:07:06.393424 [ 4871 ] {379219e9-f268-4496-bf73-35bed4e54a7f} executeQuery: Code: 57. DB::Exception: Table test_11.test1_00395 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 00395_nullable.sql) (in query: /* ddl_entry=query-0000000044 */ CREATE TABLE test_11.test1_00395 UUID '059e46ff-08fa-4693-97a3-bcf66f85b86a' (`col1` UInt64, `col2` Nullable(UInt64), `col3` String, `col4` Nullable(String), `col5` Array(UInt64), `col6` Array(Nullable(UInt64)), `col7` Array(String), `col8` Array(Nullable(String)), `d` Date) ENGINE = Memory), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 12. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:07:06.447135 [ 4871 ] {379219e9-f268-4496-bf73-35bed4e54a7f} executeQuery: Code: 57. DB::Exception: Table test_11.test1_00395 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39884) (comment: 00395_nullable.sql) (query 14, line 30) (in query: CREATE TABLE test1_00395( col1 UInt64, col2 Nullable(UInt64), col3 String, col4 Nullable(String), col5 Array(UInt64), col6 Array(Nullable(UInt64)), col7 Array(String), col8 Array(Nullable(String)), d Date) Engine = Memory;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 12. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:07:06.465953 [ 4871 ] {} TCPHandler: Code: 57. DB::Exception: Table test_11.test1_00395 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 12. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:07:07.326483 [ 3542 ] {6adc3eb1-163d-4a69-b47d-2b10a51016f4} executeQuery: Code: 36. DB::Exception: Needle must not contain whitespace or separator characters: while executing 'FUNCTION hasToken(s : 0, 'abc,def,zzz'_String :: 1) -> hasToken(__table1.s, 'abc,def,zzz'_String) UInt8 : 2': While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39904) (comment: 00990_hasToken_and_tokenbf.sql) (query 7, line 15) (in query: SELECT max(id) FROM bloom_filter WHERE hasToken(s, 'abc,def,zzz');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/HasTokenImpl.h:60: DB::HasTokenImpl>, false>::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) @ 0x000000000c1596c1 5. /build/src/Functions/FunctionsStringSearch.h:326: DB::FunctionsStringSearch>, false>, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c1579f6 6. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 7. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 10. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 11. /build/src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x000000001443c9fb 12. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:1394: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) const @ 0x00000000163c5d35 13. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:110: DB::MergeTreeReadersChain::executePrewhereActions(DB::MergeTreeRangeReader&, DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) @ 0x00000000163df584 14. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:75: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x00000000163dedc4 15. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x00000000163dace0 16. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x0000000016d617ec 17. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5584 18. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 19. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 20. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 21. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 22. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 23. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 25. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:07:07.351891 [ 3542 ] {} TCPHandler: Code: 36. DB::Exception: Needle must not contain whitespace or separator characters: while executing 'FUNCTION hasToken(s : 0, 'abc,def,zzz'_String :: 1) -> hasToken(__table1.s, 'abc,def,zzz'_String) UInt8 : 2': While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/HasTokenImpl.h:60: DB::HasTokenImpl>, false>::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) @ 0x000000000c1596c1 5. /build/src/Functions/FunctionsStringSearch.h:326: DB::FunctionsStringSearch>, false>, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c1579f6 6. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 7. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 10. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 11. /build/src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x000000001443c9fb 12. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:1394: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) const @ 0x00000000163c5d35 13. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:110: DB::MergeTreeReadersChain::executePrewhereActions(DB::MergeTreeRangeReader&, DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) @ 0x00000000163df584 14. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:75: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x00000000163dedc4 15. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x00000000163dace0 16. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x0000000016d617ec 17. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5584 18. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 19. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 20. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 21. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 22. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 23. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 25. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:07:08.187217 [ 3542 ] {cc71e002-81fc-4363-84ad-11b7f44edb7a} executeQuery: Code: 36. DB::Exception: Needle must not contain whitespace or separator characters: while executing 'FUNCTION hasTokenCaseInsensitive(s : 0, 'abc,def,zzz'_String :: 1) -> hasTokenCaseInsensitive(__table1.s, 'abc,def,zzz'_String) UInt8 : 2': While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39904) (comment: 00990_hasToken_and_tokenbf.sql) (query 8, line 16) (in query: SELECT max(id) FROM bloom_filter WHERE hasTokenCaseInsensitive(s, 'abc,def,zzz');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/HasTokenImpl.h:60: DB::HasTokenImpl>, false>::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) @ 0x000000000c15e8a1 5. /build/src/Functions/FunctionsStringSearch.h:326: DB::FunctionsStringSearch>, false>, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c15cbd6 6. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 7. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 10. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 11. /build/src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x000000001443c9fb 12. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:1394: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) const @ 0x00000000163c5d35 13. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:110: DB::MergeTreeReadersChain::executePrewhereActions(DB::MergeTreeRangeReader&, DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) @ 0x00000000163df584 14. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:75: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x00000000163dedc4 15. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x00000000163dace0 16. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x0000000016d617ec 17. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5584 18. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 19. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 20. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 21. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 22. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 23. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 25. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:07:08.204340 [ 4311 ] {} test_7.t_light_sync_r2 (dc2500c3-a78d-48e8-ad35-a3e5b096a1a9): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=17, jobs=1): While reading or decompressing /var/lib/clickhouse/store/dc2/dc2500c3-a78d-48e8-ad35-a3e5b096a1a9/tmp-fetch_4_0_0_0_1/a.cmrk2 (position: 0, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: ). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x00000000130ebd1a 8. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:se190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x00000000130ebb0f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130eacce 10. /build/src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000130e21d0 11. /build/src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000130e24cb 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 13. /build/src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000017858cab 14. /build/src/Compression/CompressedReadBufferFromFile.cpp:25: DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000001785a8dd 15. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 16. /build/src/IO/ReadBuffer.h:96: DB::MergeTreeDataPartWide::loadIndexGranularityImpl(std::shared_ptr&, DB::MergeTreeIndexGranularityInfo&, DB::IDataPartStorage const&, String const&, DB::MergeTreeSettings const&) @ 0x00000000162ef096 17. /build/src/Storages/MergeTree/MergeTreeDataPartWide.cpp:203: DB::MergeTreeDataPartWide::loadIndexGranularity() @ 0x00000000162ef70c 18. /build/src/Storages/MergeTree/IMergeTreeDataPart.cpp:842: DB::IMergeTreeDataPart::loadColumnsChecksumsIndexes(bool, bool) @ 0x000000001617de28 19. /build/src/Storages/MergeTree/DataPartsExchange.cpp:893: DB::DataPartsExchange::Fetcher::downloadPartToDisk(String const&, String const&, bool, String const&, std::shared_ptr, bool, DB::ReadWriteBufferFromHTTP&, std::function> (DB::IDataPartStorage&, String const&, unsigned long)>, unsigned long, std::shared_ptr, bool) @ 0x000000001613e609 20. /build/src/Storages/MergeTree/DataPartsExchange.cpp:693: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x0000000016139223 21. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015eba47e 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015df873d 23. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015de95eb 24. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015dda45b 25. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015eb81fe 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000164fb1a3 27. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015e1bcca 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000161700b2 29. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001621dad0 30. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001621e3ba 31. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:07:08.211873 [ 3542 ] {} TCPHandler: Code: 36. DB::Exception: Needle must not contain whitespace or separator characters: while executing 'FUNCTION hasTokenCaseInsensitive(s : 0, 'abc,def,zzz'_String :: 1) -> hasTokenCaseInsensitive(__table1.s, 'abc,def,zzz'_String) UInt8 : 2': While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/HasTokenImpl.h:60: DB::HasTokenImpl>, false>::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) @ 0x000000000c15e8a1 5. /build/src/Functions/FunctionsStringSearch.h:326: DB::FunctionsStringSearch>, false>, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c15cbd6 6. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 7. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 10. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 11. /build/src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x000000001443c9fb 12. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:1394: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) const @ 0x00000000163c5d35 13. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:110: DB::MergeTreeReadersChain::executePrewhereActions(DB::MergeTreeRangeReader&, DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) @ 0x00000000163df584 14. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:75: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x00000000163dedc4 15. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x00000000163dace0 16. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x0000000016d617ec 17. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5584 18. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 19. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 20. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 21. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 22. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 23. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 25. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:07:09.383100 [ 4888 ] {adbfcc26-4265-486c-8c9a-4083081daa2b} 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 [::ffff:127.0.0.1]:49140) (comment: 00990_hasToken_and_tokenbf.sql) (query 9, line 18) (in query: SELECT max(`__table1`.`id`) AS `max(id)` FROM `test_15`.`bloom_filter` AS `__table1` WHERE hasTokenOrNull(`__table1`.`s`, 'abc,def,zzz')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda7a6 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d2752 9. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 10. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 14. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:07:09.401719 [ 4888 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda7a6 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d2752 9. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 10. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 14. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:07:09.479567 [ 3542 ] {cb4d329b-835e-4a0f-a121-37a06f0acccc} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.3:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda7a6 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d2752 9. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 10. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 14. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39904) (comment: 00990_hasToken_and_tokenbf.sql) (query 9, line 18) (in query: SELECT max(id) FROM bloom_filter WHERE hasTokenOrNull(s, 'abc,def,zzz');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fb80677 3. /build/src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x00000000166f5247 4. /build/src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000166fc432 5. /build/src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x0000000016737609 6. /build/src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000013af731e 7. /build/src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013af6952 8. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013af679a 9. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013af64e1 2025.07.13 02:07:09.520947 [ 3542 ] {} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.3:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda7a6 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d2752 9. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 10. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 14. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 : While executing Remote. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fb80677 3. /build/src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x00000000166f5247 4. /build/src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000166fc432 5. /build/src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x0000000016737609 6. /build/src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000013af731e 7. /build/src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013af6952 8. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013af679a 9. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013af64e1 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:07:09.809563 [ 5018 ] {718f3b2f-d589-4216-8efb-b7ef6ea09867} executeQuery: Code: 57. DB::Exception: Table test_4ycha9ft.local_00952 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39912) (comment: 00952_insert_into_distributed_with_materialized_column.sql) (query 20, line 39) (in query: CREATE TABLE local_00952 (date Date, value Date MATERIALIZED toDate('2017-08-01')) ENGINE = MergeTree(date, date, 8192);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:07:09.902227 [ 5018 ] {} TCPHandler: Code: 57. DB::Exception: Table test_4ycha9ft.local_00952 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:07:11.903536 [ 6166 ] {37e8c74f-2960-437a-8c04-28702481984b} 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]:46922) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/array/arrayReduce.cpp:82: DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f59100c 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 6. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80f9b 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:07:11.916063 [ 6166 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/array/arrayReduce.cpp:82: DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f59100c 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 6. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80f9b 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:07:12.400003 [ 6166 ] {24252843-a12f-412d-9c1f-6fde280bb78c} 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]:46922) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000009fd7e2b 4. /build/src/Functions/runningDifference.h:148: DB::FunctionRunningDifferenceImpl::create(std::shared_ptr) @ 0x000000000e577bc4 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012c8d35f 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012c8cc13 7. /build/src/Functions/FunctionFactory.cpp:151: DB::FunctionFactory::tryGet(String const&, std::shared_ptr) const @ 0x0000000012c8d1c1 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3313: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52c63 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:07:12.427090 [ 6166 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000009fd7e2b 4. /build/src/Functions/runningDifference.h:148: DB::FunctionRunningDifferenceImpl::create(std::shared_ptr) @ 0x000000000e577bc4 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012c8d35f 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012c8cc13 7. /build/src/Functions/FunctionFactory.cpp:151: DB::FunctionFactory::tryGet(String const&, std::shared_ptr) const @ 0x0000000012c8d1c1 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3313: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52c63 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:07:13.495943 [ 4871 ] {37fa60fe-64e0-4faa-bae0-93e80f6ff65f} 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]:39946) (comment: 01660_join_or_all.sql) (query 15, line 21) (in query: select a2, b2 from tab2 all left join tab3 on a2 = a3 or b2 = b3 ORDER BY a2, b2;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Planner/PlannerJoins.cpp:1267: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x00000000148e4aa4 5. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0e7d2 6. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 7. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:07:13.533504 [ 4871 ] {} TCPHandler: Code: 48. DB::Exception: Only `hash` join supports multiple ORs for keys in JOIN ON section. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Planner/PlannerJoins.cpp:1267: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x00000000148e4aa4 5. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0e7d2 6. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 7. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:07:13.966859 [ 4930 ] {13ccb549-05c0-42d8-b03a-86ed82541fca} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 2 (error): error here . Expected one of: Query, Query with output, EXPLAIN, EXPLAIN, SELECT query, possibly with UNION, list of union elements, SELECT query, subquery, possibly with UNION, SELECT subquery, SELECT query, WITH, FROM, SELECT, SHOW CREATE QUOTA query, SHOW CREATE, SHOW [FULL] [TEMPORARY] TABLES|DATABASES|CLUSTERS|CLUSTER|MERGES 'name' [[NOT] [I]LIKE 'str'] [LIMIT expr], SHOW, SHOW COLUMNS query, SHOW ENGINES query, SHOW ENGINES, SHOW FUNCTIONS query, SHOW FUNCTIONS, SHOW INDEXES query, SHOW SETTING query, SHOW SETTING, EXISTS or SHOW CREATE query, EXISTS, DESCRIBE FILESYSTEM CACHE query, DESCRIBE, DESC, DESCRIBE query, SHOW PROCESSLIST query, SHOW PROCESSLIST, CREATE TABLE or ATTACH TABLE query, CREATE, ATTACH, REPLACE, CREATE DATABASE query, CREATE VIEW query, CREATE DICTIONARY, CREATE LIVE VIEW query, CREATE WINDOW VIEW query, ALTER query, ALTER TABLE, ALTER TEMPORARY TABLE, ALTER DATABASE, RENAME query, RENAME DATABASE, RENAME TABLE, EXCHANGE TABLES, RENAME DICTIONARY, EXCHANGE DICTIONARIES, RENAME, DROP query, DROP, DETACH, TRUNCATE, UNDROP query, UNDROP, CHECK ALL TABLES, CHECK TABLE, KILL QUERY query, KILL, OPTIMIZE query, OPTIMIZE TABLE, WATCH query, WATCH, SHOW ACCESS query, SHOW ACCESS, ShowAccessEntitiesQuery, SHOW GRANTS query, SHOW GRANTS, SHOW PRIVILEGES query, SHOW PRIVILEGES, BACKUP or RESTORE query, BACKUP, RESTORE, INSERT query, INSERT INTO, USE query, USE, SET ROLE or SET DEFAULT ROLE query, SET ROLE DEFAULT, SET ROLE, SET DEFAULT ROLE, SET query, SET, SYSTEM query, SYSTEM, CREATE USER or ALTER USER query, ALTER USER, CREATE USER, CREATE ROLE or ALTER ROLE query, ALTER ROLE, CREATE ROLE, CREATE QUOTA or ALTER QUOTA query, ALTER QUOTA, CREATE QUOTA, CREATE ROW POLICY or ALTER ROW POLICY query, ALTER POLICY, ALTER ROW POLICY, CREATE POLICY, CREATE ROW POLICY, CREATE SETTINGS PROFILE or ALTER SETTINGS PROFILE query, ALTER SETTINGS PROFILE, ALTER PROFILE, CREATE SETTINGS PROFILE, CREATE PROFILE, CREATE FUNCTION query, DROP FUNCTION query, CREATE WORKLOAD query, DROP WORKLOAD query, CREATE RESOURCE query, DROP RESOURCE query, CREATE NAMED COLLECTION, DROP NAMED COLLECTION query, Alter NAMED COLLECTION query, ALTER, CREATE INDEX query, DROP INDEX query, DROP access entity query, MOVE access entity query, MOVE, GRANT or REVOKE query, REVOKE, GRANT, CHECK GRANT, CHECK GRANT, EXTERNAL DDL query, EXTERNAL DDL FROM, TCL query, BEGIN TRANSACTION, START TRANSACTION, COMMIT, ROLLBACK, SET TRANSACTION SNAPSHOT, Delete query, DELETE. (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:51640) (in query: error here ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000009fd29ed 3. /build/src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9acc 4. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 5. /build/src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba32be 6. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 7. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 8. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 9. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:07:13.970298 [ 4930 ] {13ccb549-05c0-42d8-b03a-86ed82541fca} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 2 (error): error here . Expected one of: Query, Query with output, EXPLAIN, EXPLAIN, SELECT query, possibly with UNION, list of union elements, SELECT query, subquery, possibly with UNION, SELECT subquery, SELECT query, WITH, FROM, SELECT, SHOW CREATE QUOTA query, SHOW CREATE, SHOW [FULL] [TEMPORARY] TABLES|DATABASES|CLUSTERS|CLUSTER|MERGES 'name' [[NOT] [I]LIKE 'str'] [LIMIT expr], SHOW, SHOW COLUMNS query, SHOW ENGINES query, SHOW ENGINES, SHOW FUNCTIONS query, SHOW FUNCTIONS, SHOW INDEXES query, SHOW SETTING query, SHOW SETTING, EXISTS or SHOW CREATE query, EXISTS, DESCRIBE FILESYSTEM CACHE query, DESCRIBE, DESC, DESCRIBE query, SHOW PROCESSLIST query, SHOW PROCESSLIST, CREATE TABLE or ATTACH TABLE query, CREATE, ATTACH, REPLACE, CREATE DATABASE query, CREATE VIEW query, CREATE DICTIONARY, CREATE LIVE VIEW query, CREATE WINDOW VIEW query, ALTER query, ALTER TABLE, ALTER TEMPORARY TABLE, ALTER DATABASE, RENAME query, RENAME DATABASE, RENAME TABLE, EXCHANGE TABLES, RENAME DICTIONARY, EXCHANGE DICTIONARIES, RENAME, DROP query, DROP, DETACH, TRUNCATE, UNDROP query, UNDROP, CHECK ALL TABLES, CHECK TABLE, KILL QUERY query, KILL, OPTIMIZE query, OPTIMIZE TABLE, WATCH query, WATCH, SHOW ACCESS query, SHOW ACCESS, ShowAccessEntitiesQuery, SHOW GRANTS query, SHOW GRANTS, SHOW PRIVILEGES query, SHOW PRIVILEGES, BACKUP or RESTORE query, BACKUP, RESTORE, INSERT query, INSERT INTO, USE query, USE, SET ROLE or SET DEFAULT ROLE query, SET ROLE DEFAULT, SET ROLE, SET DEFAULT ROLE, SET query, SET, SYSTEM query, SYSTEM, CREATE USER or ALTER USER query, ALTER USER, CREATE USER, CREATE ROLE or ALTER ROLE query, ALTER ROLE, CREATE ROLE, CREATE QUOTA or ALTER QUOTA query, ALTER QUOTA, CREATE QUOTA, CREATE ROW POLICY or ALTER ROW POLICY query, ALTER POLICY, ALTER ROW POLICY, CREATE POLICY, CREATE ROW POLICY, CREATE SETTINGS PROFILE or ALTER SETTINGS PROFILE query, ALTER SETTINGS PROFILE, ALTER PROFILE, CREATE SETTINGS PROFILE, CREATE PROFILE, CREATE FUNCTION query, DROP FUNCTION query, CREATE WORKLOAD query, DROP WORKLOAD query, CREATE RESOURCE query, DROP RESOURCE query, CREATE NAMED COLLECTION, DROP NAMED COLLECTION query, Alter NAMED COLLECTION query, ALTER, CREATE INDEX query, DROP INDEX query, DROP access entity query, MOVE access entity query, MOVE, GRANT or REVOKE query, REVOKE, GRANT, CHECK GRANT, CHECK GRANT, EXTERNAL DDL query, EXTERNAL DDL FROM, TCL query, BEGIN TRANSACTION, START TRANSACTION, COMMIT, ROLLBACK, SET TRANSACTION SNAPSHOT, Delete query, DELETE. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000009fd29ed 3. /build/src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9acc 4. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 5. /build/src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba32be 6. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 7. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 8. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 9. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:07:14.337371 [ 6166 ] {90587dd5-2b72-47ce-ac5f-481451895825} 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]:46922) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/FunctionHelpers.cpp:216: DB::checkAndGetNestedArrayOffset(DB::IColumn const**, unsigned long) @ 0x0000000012c907f8 5. /build/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 @ 0x00000000144b6fe0 6. /build/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 @ 0x00000000144b7d43 7. /build/src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000016b170dc 8. /build/src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000016b14746 9. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 10. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 11. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 12. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 14. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:07:14.357069 [ 6166 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/FunctionHelpers.cpp:216: DB::checkAndGetNestedArrayOffset(DB::IColumn const**, unsigned long) @ 0x0000000012c907f8 5. /build/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 @ 0x00000000144b6fe0 6. /build/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 @ 0x00000000144b7d43 7. /build/src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000016b170dc 8. /build/src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000016b14746 9. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 10. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 11. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 12. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 14. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:07:14.596797 [ 6166 ] {ec6128bd-abc9-4c2a-8ab5-d858f54ee9ab} 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]:46922) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/FunctionHelpers.cpp:216: DB::checkAndGetNestedArrayOffset(DB::IColumn const**, unsigned long) @ 0x0000000012c907f8 5. /build/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 @ 0x00000000144b6fe0 6. /build/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 @ 0x00000000144b7d43 7. /build/src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000016b170dc 8. /build/src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000016b14746 9. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 10. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 11. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 12. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 14. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:07:14.631209 [ 6166 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/FunctionHelpers.cpp:216: DB::checkAndGetNestedArrayOffset(DB::IColumn const**, unsigned long) @ 0x0000000012c907f8 5. /build/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 @ 0x00000000144b6fe0 6. /build/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 @ 0x00000000144b7d43 7. /build/src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000016b170dc 8. /build/src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000016b14746 9. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 10. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 11. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 12. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 14. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:07:14.886715 [ 6637 ] {48bafcbe-5d58-4d4c-a71c-5faaf721cddb} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 7.86 MiB (attempt to allocate chunk of 2.00 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34144) (comment: 02372_now_in_block.sql) (query 2, line 2) (in query: SELECT count() FROM (SELECT DISTINCT nowInBlock(), nowInBlock('Pacific/Pitcairn') FROM system.numbers LIMIT 2);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x000000000fb2dd39 4. /build/src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2cb67 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2c5bf 6. /build/src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000fa9410c 7. /build/src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000000fa92864 8. /build/src/Common/PODArray.h:118: DB::PODArray, 4096ul, Allocator, 63ul, 64ul>::resize_fill(unsigned long) @ 0x000000000e52f018 9. /build/src/Interpreters/AggregationCommon.h:66: void DB::fillFixedBatch>(unsigned long, std::vector> const&, std::vector> const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, unsigned long&) @ 0x000000000f42202b 10. /build/src/Interpreters/AggregationCommon.h:86: DB::ColumnsHashing::HashMethodKeysFixed, wide::integer<128ul, unsigned int>, void, false, false, true, false>::HashMethodKeysFixed(std::vector> const&, std::vector> const&, std::shared_ptr const&) @ 0x00000000149b0f48 11. /build/src/Processors/Transforms/DistinctTransform.cpp:39: void DB::DistinctTransform::buildFilter, HashTableCell, UInt128HashCRC32, HashTableNoState>, UInt128HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, false>>(DB::SetMethodKeysFixed, HashTableCell, UInt128HashCRC32, HashTableNoState>, UInt128HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, false>&, std::vector> const&, DB::PODArray, 63ul, 64ul>&, unsigned long, DB::SetVariantsTemplate&) const @ 0x0000000016cdada4 12. /build/src/Processors/Transforms/DistinctTransform.cpp:93: DB::DistinctTransform::transform(DB::Chunk&) @ 0x0000000016cd91ce 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:07:14.916373 [ 6166 ] {a02ed340-958a-4920-b454-94616c07dd1b} 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]:46922) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3350: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f55342 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 16. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:07:14.950707 [ 6166 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3350: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f55342 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 16. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:07:14.960351 [ 6637 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 7.86 MiB (attempt to allocate chunk of 2.00 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x000000000fb2dd39 4. /build/src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2cb67 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2c5bf 6. /build/src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000fa9410c 7. /build/src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000000fa92864 8. /build/src/Common/PODArray.h:118: DB::PODArray, 4096ul, Allocator, 63ul, 64ul>::resize_fill(unsigned long) @ 0x000000000e52f018 9. /build/src/Interpreters/AggregationCommon.h:66: void DB::fillFixedBatch>(unsigned long, std::vector> const&, std::vector> const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, unsigned long&) @ 0x000000000f42202b 10. /build/src/Interpreters/AggregationCommon.h:86: DB::ColumnsHashing::HashMethodKeysFixed, wide::integer<128ul, unsigned int>, void, false, false, true, false>::HashMethodKeysFixed(std::vector> const&, std::vector> const&, std::shared_ptr const&) @ 0x00000000149b0f48 11. /build/src/Processors/Transforms/DistinctTransform.cpp:39: void DB::DistinctTransform::buildFilter, HashTableCell, UInt128HashCRC32, HashTableNoState>, UInt128HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, false>>(DB::SetMethodKeysFixed, HashTableCell, UInt128HashCRC32, HashTableNoState>, UInt128HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, false>&, std::vector> const&, DB::PODArray, 63ul, 64ul>&, unsigned long, DB::SetVariantsTemplate&) const @ 0x0000000016cdada4 12. /build/src/Processors/Transforms/DistinctTransform.cpp:93: DB::DistinctTransform::transform(DB::Chunk&) @ 0x0000000016cd91ce 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:07:15.005267 [ 4896 ] {25327f72-b6de-43f7-8fec-cd3bd7bf2f34} executeQuery: Code: 407. DB::Exception: Can't compare decimal number due to overflow: while executing 'FUNCTION equals(__table1.a :: 0, _CAST(2147483648_UInt32, 'UInt32'_String) :: 1) -> equals(__table1.a, _CAST(2147483648_UInt32, 'UInt32'_String)) UInt8 : 3'. (DECIMAL_OVERFLOW) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39920) (comment: 00700_decimal_compare.sql) (query 30, line 50) (in query: SELECT toUInt32(2147483648) AS x, a == x FROM decimal WHERE a = 42;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Core/DecimalComparison.h:247: char8_t DB::DecimalComparison, unsigned int, DB::EqualsOp>::apply(DB::Decimal, unsigned int, int) @ 0x000000000b68de0c 5. /build/src/Core/DecimalComparison.h:288: void DB::DecimalComparison, unsigned int, DB::EqualsOp>::vectorConstant(DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, unsigned int, DB::PODArray, 63ul, 64ul>&, int) @ 0x000000000b68dedc 6. /build/src/Core/DecimalComparison.h:193: COW::immutable_ptr DB::DecimalComparison, unsigned int, DB::EqualsOp>::apply(COW::immutable_ptr const&, COW::immutable_ptr const&, int) @ 0x000000000b68d648 7. /build/src/Core/DecimalComparison.h:110: DB::DecimalComparison, unsigned int, DB::EqualsOp>::apply(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool) @ 0x000000000b68c3b1 8. /build/src/Functions/FunctionsComparison.h:115: bool DB::callOnAtLeastOneDecimalType::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool)::'lambda'(auto const&)&>(DB::TypeIndex, DB::TypeIndex, COW::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool)::'lambda'(auto const&)&) @ 0x000000000b56916c 9. /build/src/Functions/FunctionsComparison.h:119: COW::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool) @ 0x000000000b588f92 10. /build/src/Functions/FunctionsComparison.h:1409: DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b56fe9e 11. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 22. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:07:15.021703 [ 4896 ] {} TCPHandler: Code: 407. DB::Exception: Can't compare decimal number due to overflow: while executing 'FUNCTION equals(__table1.a :: 0, _CAST(2147483648_UInt32, 'UInt32'_String) :: 1) -> equals(__table1.a, _CAST(2147483648_UInt32, 'UInt32'_String)) UInt8 : 3'. (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Core/DecimalComparison.h:247: char8_t DB::DecimalComparison, unsigned int, DB::EqualsOp>::apply(DB::Decimal, unsigned int, int) @ 0x000000000b68de0c 5. /build/src/Core/DecimalComparison.h:288: void DB::DecimalComparison, unsigned int, DB::EqualsOp>::vectorConstant(DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, unsigned int, DB::PODArray, 63ul, 64ul>&, int) @ 0x000000000b68dedc 6. /build/src/Core/DecimalComparison.h:193: COW::immutable_ptr DB::DecimalComparison, unsigned int, DB::EqualsOp>::apply(COW::immutable_ptr const&, COW::immutable_ptr const&, int) @ 0x000000000b68d648 7. /build/src/Core/DecimalComparison.h:110: DB::DecimalComparison, unsigned int, DB::EqualsOp>::apply(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool) @ 0x000000000b68c3b1 8. /build/src/Functions/FunctionsComparison.h:115: bool DB::callOnAtLeastOneDecimalType::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool)::'lambda'(auto const&)&>(DB::TypeIndex, DB::TypeIndex, COW::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool)::'lambda'(auto const&)&) @ 0x000000000b56916c 9. /build/src/Functions/FunctionsComparison.h:119: COW::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool) @ 0x000000000b588f92 10. /build/src/Functions/FunctionsComparison.h:1409: DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b56fe9e 11. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 22. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:07:15.143902 [ 6166 ] {77b05504-135c-4cc4-b3cb-2fcb8af84ff8} 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]:46922) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3350: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f55342 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 16. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:07:15.169923 [ 6166 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3350: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f55342 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 16. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:07:15.381104 [ 6166 ] {4520e834-60b7-4af1-bd50-6fce817a5e0d} 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]:46922) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/FunctionHelpers.cpp:216: DB::checkAndGetNestedArrayOffset(DB::IColumn const**, unsigned long) @ 0x0000000012c907f8 5. /build/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 @ 0x00000000144b6fe0 6. /build/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 @ 0x00000000144b7d43 7. /build/src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000016b170dc 8. /build/src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000016b14746 9. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 10. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 11. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 12. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 14. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:07:15.398499 [ 6166 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/FunctionHelpers.cpp:216: DB::checkAndGetNestedArrayOffset(DB::IColumn const**, unsigned long) @ 0x0000000012c907f8 5. /build/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 @ 0x00000000144b6fe0 6. /build/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 @ 0x00000000144b7d43 7. /build/src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000016b170dc 8. /build/src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000016b14746 9. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 10. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 11. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 12. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 14. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:07:15.776581 [ 6166 ] {375a5243-fe5f-4296-864e-1ef08b47e2a5} 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]:46922) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/FunctionHelpers.cpp:216: DB::checkAndGetNestedArrayOffset(DB::IColumn const**, unsigned long) @ 0x0000000012c907f8 5. /build/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 @ 0x00000000144b6fe0 6. /build/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 @ 0x00000000144b7d43 7. /build/src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000016b170dc 8. /build/src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000016b14746 9. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 10. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 11. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 12. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 14. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:07:15.801839 [ 6166 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/FunctionHelpers.cpp:216: DB::checkAndGetNestedArrayOffset(DB::IColumn const**, unsigned long) @ 0x0000000012c907f8 5. /build/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 @ 0x00000000144b6fe0 6. /build/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 @ 0x00000000144b7d43 7. /build/src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000016b170dc 8. /build/src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000016b14746 9. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 10. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 11. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 12. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 14. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:07:15.889355 [ 4896 ] {e4af5032-21f6-49c8-b81c-e3f4a62c7f01} executeQuery: Code: 407. DB::Exception: Can't compare decimal number due to overflow: while executing 'FUNCTION equals(__table1.b :: 0, _CAST(9223372036854775808_UInt64, 'UInt64'_String) :: 1) -> equals(__table1.b, _CAST(9223372036854775808_UInt64, 'UInt64'_String)) UInt8 : 3'. (DECIMAL_OVERFLOW) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39920) (comment: 00700_decimal_compare.sql) (query 32, line 52) (in query: SELECT toUInt64(9223372036854775808) AS x, b == x FROM decimal WHERE a = 42;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Core/DecimalComparison.h:247: char8_t DB::DecimalComparison, unsigned long, DB::EqualsOp>::apply(DB::Decimal, unsigned long, long) @ 0x000000000b6c7cce 5. /build/src/Core/DecimalComparison.h:288: void DB::DecimalComparison, unsigned long, DB::EqualsOp>::vectorConstant(DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, unsigned long, DB::PODArray, 63ul, 64ul>&, long) @ 0x000000000b6c7d9e 6. /build/src/Core/DecimalComparison.h:193: COW::immutable_ptr DB::DecimalComparison, unsigned long, DB::EqualsOp>::apply(COW::immutable_ptr const&, COW::immutable_ptr const&, long) @ 0x000000000b6c76dd 7. /build/src/Core/DecimalComparison.h:110: DB::DecimalComparison, unsigned long, DB::EqualsOp>::apply(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool) @ 0x000000000b6c6b2d 8. /build/src/Functions/FunctionsComparison.h:115: bool DB::callOnAtLeastOneDecimalType::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool)::'lambda'(auto const&)&>(DB::TypeIndex, DB::TypeIndex, COW::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool)::'lambda'(auto const&)&) @ 0x000000000b5694c1 9. /build/src/Functions/FunctionsComparison.h:119: COW::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool) @ 0x000000000b588f92 10. /build/src/Functions/FunctionsComparison.h:1409: DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b56fe9e 11. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 22. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:07:15.937923 [ 4896 ] {} TCPHandler: Code: 407. DB::Exception: Can't compare decimal number due to overflow: while executing 'FUNCTION equals(__table1.b :: 0, _CAST(9223372036854775808_UInt64, 'UInt64'_String) :: 1) -> equals(__table1.b, _CAST(9223372036854775808_UInt64, 'UInt64'_String)) UInt8 : 3'. (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Core/DecimalComparison.h:247: char8_t DB::DecimalComparison, unsigned long, DB::EqualsOp>::apply(DB::Decimal, unsigned long, long) @ 0x000000000b6c7cce 5. /build/src/Core/DecimalComparison.h:288: void DB::DecimalComparison, unsigned long, DB::EqualsOp>::vectorConstant(DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, unsigned long, DB::PODArray, 63ul, 64ul>&, long) @ 0x000000000b6c7d9e 6. /build/src/Core/DecimalComparison.h:193: COW::immutable_ptr DB::DecimalComparison, unsigned long, DB::EqualsOp>::apply(COW::immutable_ptr const&, COW::immutable_ptr const&, long) @ 0x000000000b6c76dd 7. /build/src/Core/DecimalComparison.h:110: DB::DecimalComparison, unsigned long, DB::EqualsOp>::apply(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool) @ 0x000000000b6c6b2d 8. /build/src/Functions/FunctionsComparison.h:115: bool DB::callOnAtLeastOneDecimalType::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool)::'lambda'(auto const&)&>(DB::TypeIndex, DB::TypeIndex, COW::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool)::'lambda'(auto const&)&) @ 0x000000000b5694c1 9. /build/src/Functions/FunctionsComparison.h:119: COW::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool) @ 0x000000000b588f92 10. /build/src/Functions/FunctionsComparison.h:1409: DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b56fe9e 11. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 22. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:07:16.214182 [ 6166 ] {20553572-80e3-45a7-b726-91c99706d2b0} 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]:46922) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/FunctionHelpers.cpp:216: DB::checkAndGetNestedArrayOffset(DB::IColumn const**, unsigned long) @ 0x0000000012c907f8 5. /build/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 @ 0x00000000144b6fe0 6. /build/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 @ 0x00000000144b7d43 7. /build/src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000016b170dc 8. /build/src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000016b14746 9. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 10. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 11. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 12. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 14. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:07:16.234604 [ 6166 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/FunctionHelpers.cpp:216: DB::checkAndGetNestedArrayOffset(DB::IColumn const**, unsigned long) @ 0x0000000012c907f8 5. /build/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 @ 0x00000000144b6fe0 6. /build/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 @ 0x00000000144b7d43 7. /build/src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000016b170dc 8. /build/src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000016b14746 9. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 10. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 11. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 12. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 14. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:07:16.579686 [ 6166 ] {7aeb418f-e0fa-4258-82b6-8b81b28b3875} 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]:46922) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, String&&) @ 0x000000000a9f1eeb 4. /build/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&) @ 0x0000000010682993 5. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: _ZNSt3__115allocate_sharedB8se190107IN2DB25AggregateFunctionQuantileIDB8_NS1_14QuantileTimingIS3_EENS1_26NameQuantileTimingWeightedELb1EfLb0ELb0EEENS_9allocatorIS7_EEJRKNS_6vectorINS_10shared_ptrIKNS1_9IDataTypeEEENS8_ISE_EEEERKNS1_5ArrayEETnNS_9enable_ifIXntsr8is_arrayIT_EE5valueEiE4typeELi0EEENSB_ISN_EERKT0_DpOT1_ @ 0x0000000010682425 6. /build/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*) @ 0x000000001067a368 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130caa1d 8. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 9. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:253: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000130ca98b 10. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 25. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 26. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 31. ? @ 0x00007f7210eb6ac3 2025.07.13 02:07:16.594745 [ 6166 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, String&&) @ 0x000000000a9f1eeb 4. /build/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&) @ 0x0000000010682993 5. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: _ZNSt3__115allocate_sharedB8se190107IN2DB25AggregateFunctionQuantileIDB8_NS1_14QuantileTimingIS3_EENS1_26NameQuantileTimingWeightedELb1EfLb0ELb0EEENS_9allocatorIS7_EEJRKNS_6vectorINS_10shared_ptrIKNS1_9IDataTypeEEENS8_ISE_EEEERKNS1_5ArrayEETnNS_9enable_ifIXntsr8is_arrayIT_EE5valueEiE4typeELi0EEENSB_ISN_EERKT0_DpOT1_ @ 0x0000000010682425 6. /build/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*) @ 0x000000001067a368 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130caa1d 8. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 9. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:253: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000130ca98b 10. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 25. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 26. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 31. ? @ 0x00007f7210eb6ac3 2025.07.13 02:07:17.104908 [ 6166 ] {41aae133-d8f7-418c-8ed7-9ab636a646e3} 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]:46922) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/AggregateFunctions/QuantilesCommon.h:47: DB::QuantileLevels::QuantileLevels(DB::Array const&, bool) @ 0x000000001027740b 5. /build/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*) @ 0x00000000102aeb48 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130caa1d 7. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 8. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:253: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000130ca98b 9. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:07:17.136215 [ 6166 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/AggregateFunctions/QuantilesCommon.h:47: DB::QuantileLevels::QuantileLevels(DB::Array const&, bool) @ 0x000000001027740b 5. /build/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*) @ 0x00000000102aeb48 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130caa1d 7. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 8. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:253: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000130ca98b 9. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:07:17.160089 [ 4896 ] {e454b5a6-4c53-4f13-98dd-528440a2e454} executeQuery: Code: 407. DB::Exception: Can't compare decimal number due to overflow: while executing 'FUNCTION equals(__table1.g :: 0, 30000_UInt16 :: 1) -> equals(__table1.g, 30000_UInt16) UInt8 : 2'. (DECIMAL_OVERFLOW) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39920) (comment: 00700_decimal_compare.sql) (query 36, line 57) (in query: SELECT g = 30000 FROM decimal WHERE a = 42;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Core/DecimalComparison.h:247: char8_t DB::DecimalComparison, unsigned short, DB::EqualsOp>::apply(DB::Decimal, unsigned short, int) @ 0x000000000b68a80d 5. /build/src/Core/DecimalComparison.h:288: void DB::DecimalComparison, unsigned short, DB::EqualsOp>::vectorConstant(DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, unsigned short, DB::PODArray, 63ul, 64ul>&, int) @ 0x000000000b68a8dc 6. /build/src/Core/DecimalComparison.h:193: COW::immutable_ptr DB::DecimalComparison, unsigned short, DB::EqualsOp>::apply(COW::immutable_ptr const&, COW::immutable_ptr const&, int) @ 0x000000000b689b6a 7. /build/src/Core/DecimalComparison.h:109: DB::DecimalComparison, unsigned short, DB::EqualsOp>::apply(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool) @ 0x000000000b689044 8. /build/src/Functions/FunctionsComparison.h:115: bool DB::callOnAtLeastOneDecimalType::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool)::'lambda'(auto const&)&>(DB::TypeIndex, DB::TypeIndex, COW::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool)::'lambda'(auto const&)&) @ 0x000000000b569916 9. /build/src/Functions/FunctionsComparison.h:119: COW::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool) @ 0x000000000b588f92 10. /build/src/Functions/FunctionsComparison.h:1409: DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b56fe9e 11. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 22. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:07:17.190015 [ 4896 ] {} TCPHandler: Code: 407. DB::Exception: Can't compare decimal number due to overflow: while executing 'FUNCTION equals(__table1.g :: 0, 30000_UInt16 :: 1) -> equals(__table1.g, 30000_UInt16) UInt8 : 2'. (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Core/DecimalComparison.h:247: char8_t DB::DecimalComparison, unsigned short, DB::EqualsOp>::apply(DB::Decimal, unsigned short, int) @ 0x000000000b68a80d 5. /build/src/Core/DecimalComparison.h:288: void DB::DecimalComparison, unsigned short, DB::EqualsOp>::vectorConstant(DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, unsigned short, DB::PODArray, 63ul, 64ul>&, int) @ 0x000000000b68a8dc 6. /build/src/Core/DecimalComparison.h:193: COW::immutable_ptr DB::DecimalComparison, unsigned short, DB::EqualsOp>::apply(COW::immutable_ptr const&, COW::immutable_ptr const&, int) @ 0x000000000b689b6a 7. /build/src/Core/DecimalComparison.h:109: DB::DecimalComparison, unsigned short, DB::EqualsOp>::apply(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool) @ 0x000000000b689044 8. /build/src/Functions/FunctionsComparison.h:115: bool DB::callOnAtLeastOneDecimalType::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool)::'lambda'(auto const&)&>(DB::TypeIndex, DB::TypeIndex, COW::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool)::'lambda'(auto const&)&) @ 0x000000000b569916 9. /build/src/Functions/FunctionsComparison.h:119: COW::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool) @ 0x000000000b588f92 10. /build/src/Functions/FunctionsComparison.h:1409: DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b56fe9e 11. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 22. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:07:17.516026 [ 6166 ] {81aca2a4-0b78-4688-b269-888fbc03a7be} 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]:46922) (comment: 00534_filimonov.sh) (query 139, line 444) (in query: SELECT maxIntersections([], []);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x000000001002d50b 4. /build/src/AggregateFunctions/AggregateFunctionMaxIntersections.cpp:201: DB::(anonymous namespace)::createAggregateFunctionMaxIntersections(DB::(anonymous namespace)::AggregateFunctionIntersectionsKind, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x00000000113ac3e3 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130caa1d 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:07:17.534745 [ 6166 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x000000001002d50b 4. /build/src/AggregateFunctions/AggregateFunctionMaxIntersections.cpp:201: DB::(anonymous namespace)::createAggregateFunctionMaxIntersections(DB::(anonymous namespace)::AggregateFunctionIntersectionsKind, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x00000000113ac3e3 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130caa1d 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:07:17.814988 [ 6166 ] {3d947d25-5570-45b8-965c-4f0d17171739} 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]:46922) (comment: 00534_filimonov.sh) (query 140, line 445) (in query: SELECT sumMap([], []);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a59c08b 4. /build/src/AggregateFunctions/AggregateFunctionSum.cpp:66: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionSum(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000010ce5db7 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130caa1d 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 7. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:253: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000130ca98b 8. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:07:17.846061 [ 4896 ] {72ad5788-b9b8-409c-969c-56110ae8f164} executeQuery: Code: 407. DB::Exception: Can't compare decimal number due to overflow: while executing 'FUNCTION equals(30000_UInt16 :: 1, __table1.g :: 0) -> equals(30000_UInt16, __table1.g) UInt8 : 2'. (DECIMAL_OVERFLOW) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39920) (comment: 00700_decimal_compare.sql) (query 37, line 58) (in query: SELECT 30000 = g FROM decimal WHERE a = 42;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Core/DecimalComparison.h:247: char8_t DB::DecimalComparison, DB::EqualsOp>::apply(unsigned short, DB::Decimal, int) @ 0x000000000b78ba8d 5. /build/src/Core/DecimalComparison.h:304: void DB::DecimalComparison, DB::EqualsOp>::constantVector(unsigned short, DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, int) @ 0x000000000b78bafc 6. /build/src/Core/DecimalComparison.h:184: COW::immutable_ptr DB::DecimalComparison, DB::EqualsOp>::apply(COW::immutable_ptr const&, COW::immutable_ptr const&, int) @ 0x000000000b78aed0 7. /build/src/Core/DecimalComparison.h:107: DB::DecimalComparison, DB::EqualsOp>::apply(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool) @ 0x000000000b78ab1d 8. /build/src/Functions/FunctionsComparison.h:115: bool DB::callOnAtLeastOneDecimalType::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool)::'lambda'(auto const&)&>(DB::TypeIndex, DB::TypeIndex, COW::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool)::'lambda'(auto const&)&) @ 0x000000000b56bc0c 9. /build/src/Functions/FunctionsComparison.h:119: COW::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool) @ 0x000000000b588f92 10. /build/src/Functions/FunctionsComparison.h:1409: DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b56fe9e 11. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 22. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:07:17.876029 [ 4896 ] {} TCPHandler: Code: 407. DB::Exception: Can't compare decimal number due to overflow: while executing 'FUNCTION equals(30000_UInt16 :: 1, __table1.g :: 0) -> equals(30000_UInt16, __table1.g) UInt8 : 2'. (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Core/DecimalComparison.h:247: char8_t DB::DecimalComparison, DB::EqualsOp>::apply(unsigned short, DB::Decimal, int) @ 0x000000000b78ba8d 5. /build/src/Core/DecimalComparison.h:304: void DB::DecimalComparison, DB::EqualsOp>::constantVector(unsigned short, DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, int) @ 0x000000000b78bafc 6. /build/src/Core/DecimalComparison.h:184: COW::immutable_ptr DB::DecimalComparison, DB::EqualsOp>::apply(COW::immutable_ptr const&, COW::immutable_ptr const&, int) @ 0x000000000b78aed0 7. /build/src/Core/DecimalComparison.h:107: DB::DecimalComparison, DB::EqualsOp>::apply(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool) @ 0x000000000b78ab1d 8. /build/src/Functions/FunctionsComparison.h:115: bool DB::callOnAtLeastOneDecimalType::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool)::'lambda'(auto const&)&>(DB::TypeIndex, DB::TypeIndex, COW::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool)::'lambda'(auto const&)&) @ 0x000000000b56bc0c 9. /build/src/Functions/FunctionsComparison.h:119: COW::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool) @ 0x000000000b588f92 10. /build/src/Functions/FunctionsComparison.h:1409: DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b56fe9e 11. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 22. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:07:17.901070 [ 6166 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a59c08b 4. /build/src/AggregateFunctions/AggregateFunctionSum.cpp:66: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionSum(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000010ce5db7 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130caa1d 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 7. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:253: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000130ca98b 8. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:07:18.143797 [ 6166 ] {3337af1d-aef2-459b-8cfb-50e08570891a} 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]:46922) (comment: 00534_filimonov.sh) (query 141, line 447) (in query: SELECT countArray();), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/AggregateFunctions/Combinators/AggregateFunctionArray.cpp:29: DB::(anonymous namespace)::AggregateFunctionCombinatorArray::transformArguments(std::vector, std::allocator>> const&) const @ 0x0000000011658b83 5. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:250: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000130ca938 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:07:18.247335 [ 6166 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/AggregateFunctions/Combinators/AggregateFunctionArray.cpp:29: DB::(anonymous namespace)::AggregateFunctionCombinatorArray::transformArguments(std::vector, std::allocator>> const&) const @ 0x0000000011658b83 5. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:250: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000130ca938 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:07:19.011001 [ 4896 ] {c90c9e72-04c9-40eb-8d76-b16829a18d49} executeQuery: Code: 407. DB::Exception: Can't compare decimal number due to overflow: while executing 'FUNCTION equals(__table1.h :: 0, 10000000000_UInt64 :: 1) -> equals(__table1.h, 10000000000_UInt64) UInt8 : 2'. (DECIMAL_OVERFLOW) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39920) (comment: 00700_decimal_compare.sql) (query 40, line 61) (in query: SELECT h = 10000000000 FROM decimal WHERE a = 42;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Core/DecimalComparison.h:247: char8_t DB::DecimalComparison, unsigned long, DB::EqualsOp>::apply(DB::Decimal, unsigned long, long) @ 0x000000000b6c7afd 5. /build/src/Core/DecimalComparison.h:288: void DB::DecimalComparison, unsigned long, DB::EqualsOp>::vectorConstant(DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, unsigned long, DB::PODArray, 63ul, 64ul>&, long) @ 0x000000000b6c7bde 6. /build/src/Core/DecimalComparison.h:193: COW::immutable_ptr DB::DecimalComparison, unsigned long, DB::EqualsOp>::apply(COW::immutable_ptr const&, COW::immutable_ptr const&, long) @ 0x000000000b6c6fdd 7. /build/src/Core/DecimalComparison.h:109: DB::DecimalComparison, unsigned long, DB::EqualsOp>::apply(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool) @ 0x000000000b6c6b81 8. /build/src/Functions/FunctionsComparison.h:115: bool DB::callOnAtLeastOneDecimalType::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool)::'lambda'(auto const&)&>(DB::TypeIndex, DB::TypeIndex, COW::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool)::'lambda'(auto const&)&) @ 0x000000000b5694c1 9. /build/src/Functions/FunctionsComparison.h:119: COW::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool) @ 0x000000000b588f92 10. /build/src/Functions/FunctionsComparison.h:1409: DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b56fe9e 11. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 22. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:07:19.030250 [ 4896 ] {} TCPHandler: Code: 407. DB::Exception: Can't compare decimal number due to overflow: while executing 'FUNCTION equals(__table1.h :: 0, 10000000000_UInt64 :: 1) -> equals(__table1.h, 10000000000_UInt64) UInt8 : 2'. (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Core/DecimalComparison.h:247: char8_t DB::DecimalComparison, unsigned long, DB::EqualsOp>::apply(DB::Decimal, unsigned long, long) @ 0x000000000b6c7afd 5. /build/src/Core/DecimalComparison.h:288: void DB::DecimalComparison, unsigned long, DB::EqualsOp>::vectorConstant(DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, unsigned long, DB::PODArray, 63ul, 64ul>&, long) @ 0x000000000b6c7bde 6. /build/src/Core/DecimalComparison.h:193: COW::immutable_ptr DB::DecimalComparison, unsigned long, DB::EqualsOp>::apply(COW::immutable_ptr const&, COW::immutable_ptr const&, long) @ 0x000000000b6c6fdd 7. /build/src/Core/DecimalComparison.h:109: DB::DecimalComparison, unsigned long, DB::EqualsOp>::apply(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool) @ 0x000000000b6c6b81 8. /build/src/Functions/FunctionsComparison.h:115: bool DB::callOnAtLeastOneDecimalType::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool)::'lambda'(auto const&)&>(DB::TypeIndex, DB::TypeIndex, COW::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool)::'lambda'(auto const&)&) @ 0x000000000b5694c1 9. /build/src/Functions/FunctionsComparison.h:119: COW::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool) @ 0x000000000b588f92 10. /build/src/Functions/FunctionsComparison.h:1409: DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b56fe9e 11. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 22. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:07:19.478013 [ 3543 ] {4dd120a7-9b10-4330-849a-ab247543e2cd} test_9.mt_compact (09c9e263-d383-464a-9038-4270e4e52d6b): 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:07:19.973742 [ 3543 ] {eaf7a659-981f-49fd-966d-9a94d2cf078c} 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]:51332) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3897: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001625c740 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd033 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:07:20.037797 [ 3543 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3897: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001625c740 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd033 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:07:21.083989 [ 16757 ] {cad33fd0-dc0f-40d4-9703-92cd82553600} executeQuery: Code: 201. DB::Exception: Quota for user `quoted_by_ip_test_4f7idds2` for 31556952s has been exceeded: queries = 2/1. Interval will end at 2026-02-09 04:56:21. Name of quota template: `quota_by_ip_test_4f7idds2`. (QUOTA_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:43708) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::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&&) @ 0x00000000136f3099 4. /build/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>>) @ 0x00000000136f2eb2 5. /build/src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x00000000136f1503 6. /build/src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x00000000136f131a 7. /build/src/Interpreters/executeQuery.cpp:1420: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba68a8 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 9. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:07:21.092581 [ 16757 ] {cad33fd0-dc0f-40d4-9703-92cd82553600} DynamicQueryHandler: Code: 201. DB::Exception: Quota for user `quoted_by_ip_test_4f7idds2` for 31556952s has been exceeded: queries = 2/1. Interval will end at 2026-02-09 04:56:21. Name of quota template: `quota_by_ip_test_4f7idds2`. (QUOTA_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::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&&) @ 0x00000000136f3099 4. /build/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>>) @ 0x00000000136f2eb2 5. /build/src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x00000000136f1503 6. /build/src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x00000000136f131a 7. /build/src/Interpreters/executeQuery.cpp:1420: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba68a8 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 9. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:07:21.178069 [ 16757 ] {cad33fd0-dc0f-40d4-9703-92cd82553600} 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]:43708). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fc62e75 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fc64467 4. /build/src/Server/HTTP/HTTPServerResponse.h:197: DB::HTTPWriteBuffer::nextImplChunked() @ 0x000000001682f8f4 5. /build/src/Server/HTTP/HTTPServerResponse.h:166: DB::WriteBufferFromHTTPServerResponse::nextImpl() @ 0x000000001682d8f4 6. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x0000000009fb95be 7. /build/src/IO/WriteBuffer.h:127: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x000000001682dfff 8. /build/src/IO/WriteBuffer.cpp:95: DB::WriteBuffer::finalize() @ 0x000000000fb98f30 9. /build/src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:282: DB::WriteBufferFromHTTPServerResponse::cancelWithException(DB::HTTPServerRequest&, int, String const&, DB::WriteBuffer*) @ 0x000000001682e552 10. /build/src/Server/HTTPHandler.cpp:664: DB::HTTPHandler::trySendExceptionToClient(int, String const&, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x000000001678f7ee 11. /build/src/Server/HTTPHandler.cpp:771: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016791c23 12. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:07:21.305196 [ 3543 ] {0aa4ea4d-4c64-4668-9614-4039c0f63f33} 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]:51332) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String const&) @ 0x000000000fd242eb 4. /build/src/Storages/StorageMergeTree.cpp:2272: DB::StorageMergeTree::replacePartitionFrom(std::shared_ptr const&, std::shared_ptr const&, bool, std::shared_ptr) @ 0x000000001657c2b9 5. /build/src/Storages/MergeTree/MergeTreeData.cpp:5751: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000001627bc4d 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:242: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd4b7 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 10. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:07:21.337020 [ 3543 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String const&) @ 0x000000000fd242eb 4. /build/src/Storages/StorageMergeTree.cpp:2272: DB::StorageMergeTree::replacePartitionFrom(std::shared_ptr const&, std::shared_ptr const&, bool, std::shared_ptr) @ 0x000000001657c2b9 5. /build/src/Storages/MergeTree/MergeTreeData.cpp:5751: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000001627bc4d 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:242: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd4b7 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 10. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:07:21.503620 [ 16758 ] {5b1996b1-4ed3-49b2-892c-d77b8ef68131} executeQuery: Code: 201. DB::Exception: Quota for user `quoted_by_ip_test_4f7idds2` for 31556952s has been exceeded: queries = 3/1. Interval will end at 2026-02-09 04:56:21. Name of quota template: `quota_by_ip_test_4f7idds2`. (QUOTA_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:43718) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::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&&) @ 0x00000000136f3099 4. /build/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>>) @ 0x00000000136f2eb2 5. /build/src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x00000000136f1503 6. /build/src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x00000000136f131a 7. /build/src/Interpreters/executeQuery.cpp:1420: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba68a8 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 9. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:07:21.510411 [ 16758 ] {5b1996b1-4ed3-49b2-892c-d77b8ef68131} DynamicQueryHandler: Code: 201. DB::Exception: Quota for user `quoted_by_ip_test_4f7idds2` for 31556952s has been exceeded: queries = 3/1. Interval will end at 2026-02-09 04:56:21. Name of quota template: `quota_by_ip_test_4f7idds2`. (QUOTA_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::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&&) @ 0x00000000136f3099 4. /build/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>>) @ 0x00000000136f2eb2 5. /build/src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x00000000136f1503 6. /build/src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x00000000136f131a 7. /build/src/Interpreters/executeQuery.cpp:1420: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba68a8 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 9. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:07:21.936156 [ 4922 ] {79f1234c-757d-4a30-9b01-9d9f414ee27d} executeQuery: Code: 201. DB::Exception: Quota for user `quoted_by_ip_test_4f7idds2` for 31556952s has been exceeded: queries = 4/1. Interval will end at 2026-02-09 04:56:21. Name of quota template: `quota_by_ip_test_4f7idds2`. (QUOTA_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:43734) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::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&&) @ 0x00000000136f3099 4. /build/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>>) @ 0x00000000136f2eb2 5. /build/src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x00000000136f1503 6. /build/src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x00000000136f131a 7. /build/src/Interpreters/executeQuery.cpp:1420: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba68a8 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 9. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:07:22.021925 [ 4922 ] {79f1234c-757d-4a30-9b01-9d9f414ee27d} DynamicQueryHandler: Code: 201. DB::Exception: Quota for user `quoted_by_ip_test_4f7idds2` for 31556952s has been exceeded: queries = 4/1. Interval will end at 2026-02-09 04:56:21. Name of quota template: `quota_by_ip_test_4f7idds2`. (QUOTA_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::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&&) @ 0x00000000136f3099 4. /build/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>>) @ 0x00000000136f2eb2 5. /build/src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x00000000136f1503 6. /build/src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x00000000136f131a 7. /build/src/Interpreters/executeQuery.cpp:1420: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba68a8 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 9. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:07:22.243262 [ 3543 ] {776a90d8-fe9c-400c-a072-98dee3200baa} test_9.mt_compact (f2d11c7d-3995-46f2-9b9d-802f12f7bbd8): 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:07:22.939627 [ 4871 ] {61c1f933-7acc-4b0a-a7c0-8fa91e01edb6} executeQuery: Code: 549. DB::Exception: Column `m1` with type Map(String, AggregateFunction(sum, UInt32)) 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: 03034_ddls_and_merges_with_unusual_maps.sql) (in query: /* ddl_entry=query-0000000049 */ CREATE TABLE test_5.tab UUID 'b2e77a26-d8b5-416d-9aea-060495c9b15c' (`m1` Map(String, AggregateFunction(sum, UInt32))) ENGINE = MergeTree ORDER BY m1 SETTINGS index_granularity = 48133, min_bytes_for_wide_part = 406989749, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 73, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 83503641, compact_parts_max_granules_to_buffer = 108, compact_parts_merge_max_bytes_to_prefetch_part = 2194246, merge_max_block_size = 23363, 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 = 1, index_granularity_bytes = 1112701, 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 = 18852, primary_key_compress_block_size = 36200, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Storages/KeyDescription.cpp:174: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x0000000015c4f0c4 5. /build/src/Storages/MergeTree/registerStorageMergeTree.cpp:668: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000016551c80 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ca1a22 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001481ee32 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 12. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 13. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 14. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 15. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 16. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 17. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 18. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:07:23.064902 [ 4871 ] {61c1f933-7acc-4b0a-a7c0-8fa91e01edb6} executeQuery: Code: 549. DB::Exception: Column `m1` with type Map(String, AggregateFunction(sum, UInt32)) 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]:51368) (comment: 03034_ddls_and_merges_with_unusual_maps.sql) (query 4, line 8) (in query: CREATE TABLE tab (`m1` Map(String, AggregateFunction(sum, UInt32))) ENGINE = MergeTree ORDER BY m1 SETTINGS index_granularity = 48133, min_bytes_for_wide_part = 406989749, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 73, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 83503641, compact_parts_max_granules_to_buffer = 108, compact_parts_merge_max_bytes_to_prefetch_part = 2194246, merge_max_block_size = 23363, 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 = 1, index_granularity_bytes = 1112701, 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 = 18852, primary_key_compress_block_size = 36200, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Storages/KeyDescription.cpp:174: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x0000000015c4f0c4 5. /build/src/Storages/MergeTree/registerStorageMergeTree.cpp:668: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000016551c80 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ca1a22 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001481ee32 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 12. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 13. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 14. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 15. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 16. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 17. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 18. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:07:23.079573 [ 4871 ] {} TCPHandler: Code: 549. DB::Exception: Column `m1` with type Map(String, AggregateFunction(sum, UInt32)) 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Storages/KeyDescription.cpp:174: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x0000000015c4f0c4 5. /build/src/Storages/MergeTree/registerStorageMergeTree.cpp:668: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000016551c80 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ca1a22 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001481ee32 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 12. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 13. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 14. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 15. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 16. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 17. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 18. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:07:23.129733 [ 4922 ] {c93b4cd1-c25a-45d7-9aeb-afc97f8a5735} executeQuery: Code: 201. DB::Exception: Quota for user `quoted_by_forwarded_ip_test_4f7idds2` for 31556952s has been exceeded: queries = 2/1. Interval will end at 2026-04-13 16:09:23. Name of quota template: `quota_by_forwarded_ip_test_4f7idds2`. (QUOTA_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:43758) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::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&&) @ 0x00000000136f3099 4. /build/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>>) @ 0x00000000136f2eb2 5. /build/src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x00000000136f1503 6. /build/src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x00000000136f131a 7. /build/src/Interpreters/executeQuery.cpp:1420: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba68a8 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 9. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:07:23.179522 [ 4922 ] {c93b4cd1-c25a-45d7-9aeb-afc97f8a5735} DynamicQueryHandler: Code: 201. DB::Exception: Quota for user `quoted_by_forwarded_ip_test_4f7idds2` for 31556952s has been exceeded: queries = 2/1. Interval will end at 2026-04-13 16:09:23. Name of quota template: `quota_by_forwarded_ip_test_4f7idds2`. (QUOTA_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::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&&) @ 0x00000000136f3099 4. /build/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>>) @ 0x00000000136f2eb2 5. /build/src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x00000000136f1503 6. /build/src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x00000000136f131a 7. /build/src/Interpreters/executeQuery.cpp:1420: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba68a8 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 9. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:07:23.190329 [ 4922 ] {c93b4cd1-c25a-45d7-9aeb-afc97f8a5735} 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]:43758). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fc62e75 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fc64467 4. /build/src/Server/HTTP/HTTPServerResponse.h:197: DB::HTTPWriteBuffer::nextImplChunked() @ 0x000000001682f8f4 5. /build/src/Server/HTTP/HTTPServerResponse.h:166: DB::WriteBufferFromHTTPServerResponse::nextImpl() @ 0x000000001682d8f4 6. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x0000000009fb95be 7. /build/src/IO/WriteBuffer.h:127: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x000000001682dfff 8. /build/src/IO/WriteBuffer.cpp:95: DB::WriteBuffer::finalize() @ 0x000000000fb98f30 9. /build/src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:282: DB::WriteBufferFromHTTPServerResponse::cancelWithException(DB::HTTPServerRequest&, int, String const&, DB::WriteBuffer*) @ 0x000000001682e552 10. /build/src/Server/HTTPHandler.cpp:664: DB::HTTPHandler::trySendExceptionToClient(int, String const&, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x000000001678f7ee 11. /build/src/Server/HTTPHandler.cpp:771: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016791c23 12. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:07:23.468074 [ 6614 ] {196300aa-9b74-46cb-bdd9-62fc9d33ebba} executeQuery: Code: 201. DB::Exception: Quota for user `quoted_by_forwarded_ip_test_4f7idds2` for 31556952s has been exceeded: queries = 3/1. Interval will end at 2026-04-13 16:09:23. Name of quota template: `quota_by_forwarded_ip_test_4f7idds2`. (QUOTA_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:43760) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::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&&) @ 0x00000000136f3099 4. /build/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>>) @ 0x00000000136f2eb2 5. /build/src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x00000000136f1503 6. /build/src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x00000000136f131a 7. /build/src/Interpreters/executeQuery.cpp:1420: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba68a8 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 9. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:07:23.479363 [ 6614 ] {196300aa-9b74-46cb-bdd9-62fc9d33ebba} DynamicQueryHandler: Code: 201. DB::Exception: Quota for user `quoted_by_forwarded_ip_test_4f7idds2` for 31556952s has been exceeded: queries = 3/1. Interval will end at 2026-04-13 16:09:23. Name of quota template: `quota_by_forwarded_ip_test_4f7idds2`. (QUOTA_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::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&&) @ 0x00000000136f3099 4. /build/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>>) @ 0x00000000136f2eb2 5. /build/src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x00000000136f1503 6. /build/src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x00000000136f131a 7. /build/src/Interpreters/executeQuery.cpp:1420: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba68a8 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 9. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:07:24.382181 [ 4922 ] {122a5771-3c4c-4136-aa8d-c43072e931b6} executeQuery: Code: 201. DB::Exception: Quota for user `quoted_by_forwarded_ip_test_4f7idds2` for 31556952s has been exceeded: queries = 2/1. Interval will end at 2026-02-19 14:22:52. Name of quota template: `quota_by_forwarded_ip_test_4f7idds2`. (QUOTA_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:43786) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::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&&) @ 0x00000000136f3099 4. /build/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>>) @ 0x00000000136f2eb2 5. /build/src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x00000000136f1503 6. /build/src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x00000000136f131a 7. /build/src/Interpreters/executeQuery.cpp:1420: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba68a8 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 9. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:07:24.387609 [ 4922 ] {122a5771-3c4c-4136-aa8d-c43072e931b6} DynamicQueryHandler: Code: 201. DB::Exception: Quota for user `quoted_by_forwarded_ip_test_4f7idds2` for 31556952s has been exceeded: queries = 2/1. Interval will end at 2026-02-19 14:22:52. Name of quota template: `quota_by_forwarded_ip_test_4f7idds2`. (QUOTA_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::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&&) @ 0x00000000136f3099 4. /build/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>>) @ 0x00000000136f2eb2 5. /build/src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x00000000136f1503 6. /build/src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x00000000136f131a 7. /build/src/Interpreters/executeQuery.cpp:1420: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba68a8 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 9. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:07:24.648293 [ 4922 ] {c433f8d5-7942-41bb-9cbe-830bbf807ea1} executeQuery: Code: 201. DB::Exception: Quota for user `quoted_by_forwarded_ip_test_4f7idds2` for 31556952s has been exceeded: queries = 3/1. Interval will end at 2026-02-19 14:22:52. Name of quota template: `quota_by_forwarded_ip_test_4f7idds2`. (QUOTA_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:43788) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::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&&) @ 0x00000000136f3099 4. /build/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>>) @ 0x00000000136f2eb2 5. /build/src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x00000000136f1503 6. /build/src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x00000000136f131a 7. /build/src/Interpreters/executeQuery.cpp:1420: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba68a8 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 9. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:07:24.661027 [ 4922 ] {c433f8d5-7942-41bb-9cbe-830bbf807ea1} DynamicQueryHandler: Code: 201. DB::Exception: Quota for user `quoted_by_forwarded_ip_test_4f7idds2` for 31556952s has been exceeded: queries = 3/1. Interval will end at 2026-02-19 14:22:52. Name of quota template: `quota_by_forwarded_ip_test_4f7idds2`. (QUOTA_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::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&&) @ 0x00000000136f3099 4. /build/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>>) @ 0x00000000136f2eb2 5. /build/src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x00000000136f1503 6. /build/src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x00000000136f131a 7. /build/src/Interpreters/executeQuery.cpp:1420: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba68a8 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 9. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:07:24.984943 [ 3542 ] {97e81e21-b6ad-4c11-a47c-b18e395b4a89} executeQuery: Code: 201. DB::Exception: Quota for user `quoted_by_forwarded_ip_test_4f7idds2` for 31556952s has been exceeded: queries = 4/1. Interval will end at 2026-02-19 14:22:52. Name of quota template: `quota_by_forwarded_ip_test_4f7idds2`. (QUOTA_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:43802) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::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&&) @ 0x00000000136f3099 4. /build/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>>) @ 0x00000000136f2eb2 5. /build/src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x00000000136f1503 6. /build/src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x00000000136f131a 7. /build/src/Interpreters/executeQuery.cpp:1420: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba68a8 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 9. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:07:24.993039 [ 3542 ] {97e81e21-b6ad-4c11-a47c-b18e395b4a89} DynamicQueryHandler: Code: 201. DB::Exception: Quota for user `quoted_by_forwarded_ip_test_4f7idds2` for 31556952s has been exceeded: queries = 4/1. Interval will end at 2026-02-19 14:22:52. Name of quota template: `quota_by_forwarded_ip_test_4f7idds2`. (QUOTA_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::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&&) @ 0x00000000136f3099 4. /build/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>>) @ 0x00000000136f2eb2 5. /build/src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x00000000136f1503 6. /build/src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x00000000136f131a 7. /build/src/Interpreters/executeQuery.cpp:1420: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba68a8 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 9. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:07:25.094775 [ 4871 ] {64d5ffc4-002d-4c45-8730-9015d14c698c} executeQuery: Code: 57. DB::Exception: Table test_5.tab already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 03034_ddls_and_merges_with_unusual_maps.sql) (in query: /* ddl_entry=query-0000000051 */ CREATE TABLE test_5.tab UUID '291713f6-f5f5-4ba9-9316-97df85e237a5' (`m1` Map(Float32, String), `m2` Map(LowCardinality(String), String)) ENGINE = MergeTree ORDER BY (m1, m2) SETTINGS index_granularity = 48133, min_bytes_for_wide_part = 406989749, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 73, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 83503641, compact_parts_max_granules_to_buffer = 108, compact_parts_merge_max_bytes_to_prefetch_part = 2194246, merge_max_block_size = 23363, 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 = 1, index_granularity_bytes = 1112701, 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 = 18852, primary_key_compress_block_size = 36200, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 12. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:07:25.232469 [ 4871 ] {64d5ffc4-002d-4c45-8730-9015d14c698c} executeQuery: Code: 57. DB::Exception: Table test_5.tab already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51368) (comment: 03034_ddls_and_merges_with_unusual_maps.sql) (query 9, line 17) (in query: CREATE TABLE tab (`m1` Map(Float32, String), `m2` Map(LowCardinality(String), String)) ENGINE = MergeTree ORDER BY (m1, m2) SETTINGS index_granularity = 48133, min_bytes_for_wide_part = 406989749, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 73, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 83503641, compact_parts_max_granules_to_buffer = 108, compact_parts_merge_max_bytes_to_prefetch_part = 2194246, merge_max_block_size = 23363, 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 = 1, index_granularity_bytes = 1112701, 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 = 18852, primary_key_compress_block_size = 36200, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 12. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:07:25.253816 [ 4871 ] {} TCPHandler: Code: 57. DB::Exception: Table test_5.tab already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 12. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:07:25.658078 [ 3542 ] {94c74f35-2f53-4495-8165-6d8ea8acf647} 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]:51442) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a59c08b 4. /build/src/AggregateFunctions/AggregateFunctionDeltaSumTimestamp.cpp:237: DB::(anonymous namespace)::createAggregateFunctionDeltaSumTimestamp(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000010049635 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130caa1d 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:07:25.708574 [ 3542 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a59c08b 4. /build/src/AggregateFunctions/AggregateFunctionDeltaSumTimestamp.cpp:237: DB::(anonymous namespace)::createAggregateFunctionDeltaSumTimestamp(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000010049635 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130caa1d 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:07:27.214217 [ 4922 ] {7ef5241c-f7be-4e32-bd83-4291cc816f5d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51434) (comment: 03203_system_query_metric_log.sh) (query 2, line 3) (in query: SELECT count() == 0 FROM system.query_metric_log WHERE event_date >= yesterday() AND query_id = 'test_3_fast' ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x00000000163993d1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016396620 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001639641f 10. /build/src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000163b2bd7 11. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x00000000162ea22d 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x00000000162e6974 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x00000000163d9ded 14. /build/src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x0000000016d7885f 15. /build/src/Storages/MergeTree/MergeTreeReadPool.cpp:159: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x0000000016d96c0a 16. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5520 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 18. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 22. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:07:27.297046 [ 4922 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x00000000163993d1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016396620 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001639641f 10. /build/src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000163b2bd7 11. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x00000000162ea22d 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x00000000162e6974 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x00000000163d9ded 14. /build/src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x0000000016d7885f 15. /build/src/Storages/MergeTree/MergeTreeReadPool.cpp:159: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x0000000016d96c0a 16. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5520 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 18. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 22. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:07:29.154690 [ 4888 ] {282de833-bb13-4738-b966-716c92b857ed} 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]:51358) (comment: 02941_variant_type_2.sh) (query 1, line 1) (in query: optimize table test final;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000000fb2dc4b 4. /build/src/Common/MemoryTracker.cpp:196: MemoryTracker::injectFault() const @ 0x000000000fb2b6cd 5. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:153: DB::MergePlainMergeTreeTask::finish() @ 0x0000000016593639 6. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:72: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000016592af2 7. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x0000000016564e9a 8. /build/src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000001656bb83 9. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014bf58ce 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:07:29.171012 [ 4888 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000000fb2dc4b 4. /build/src/Common/MemoryTracker.cpp:196: MemoryTracker::injectFault() const @ 0x000000000fb2b6cd 5. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:153: DB::MergePlainMergeTreeTask::finish() @ 0x0000000016593639 6. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:72: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000016592af2 7. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x0000000016564e9a 8. /build/src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000001656bb83 9. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014bf58ce 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:07:29.823131 [ 16765 ] {5ae2b754-031d-40cb-9a60-0902029656f7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=851, jobs=796). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34152) (comment: 00410_aggregation_combinators_with_arenas.sql) (query 9, line 10) (in query: SELECT min(x), max(x) FROM (SELECT length(arrayReduce('groupUniqArray', [hex(number), hex(number+1), hex(number)])) AS x FROM system.numbers LIMIT 100000);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbdd1d3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd751c 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 9. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 10. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:07:29.847967 [ 16765 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=851, jobs=796). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbdd1d3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd751c 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 9. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 10. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:07:30.918814 [ 3542 ] {930456cc-b740-4465-8aba-719a2464aaf1} executeQuery: Code: 36. DB::Exception: No such attribute 'prefixprefixprefixprefix': In scope SELECT '127.0.0.0/24' = dictGetString(concat('test_07omevd0', '.dict_ipv4_trie'), 'prefixprefixprefixprefix', tuple(IPv4StringToNumOrDefault('127.0.0.0127.0.0.0'))). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51472) (comment: 01018_ip_dictionary_long.sql) (query 13, line 44) (in query: SELECT '127.0.0.0/24' = dictGetString(concat('test_07omevd0', '.dict_ipv4_trie'), 'prefixprefixprefixprefix', tuple(IPv4StringToNumOrDefault('127.0.0.0127.0.0.0')))), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Dictionaries/DictionaryStructure.cpp:176: DB::DictionaryStructure::getAttribute(String const&) const @ 0x0000000012c7c76a 5. /build/src/Functions/FunctionsExternalDictionaries.h:382: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a113ab2 6. /build/src/Functions/FunctionsExternalDictionaries.h:823: DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a12d3ef 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 31. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 2025.07.13 02:07:30.925258 [ 3542 ] {} TCPHandler: Code: 36. DB::Exception: No such attribute 'prefixprefixprefixprefix': In scope SELECT '127.0.0.0/24' = dictGetString(concat('test_07omevd0', '.dict_ipv4_trie'), 'prefixprefixprefixprefix', tuple(IPv4StringToNumOrDefault('127.0.0.0127.0.0.0'))). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Dictionaries/DictionaryStructure.cpp:176: DB::DictionaryStructure::getAttribute(String const&) const @ 0x0000000012c7c76a 5. /build/src/Functions/FunctionsExternalDictionaries.h:382: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a113ab2 6. /build/src/Functions/FunctionsExternalDictionaries.h:823: DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a12d3ef 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 31. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 2025.07.13 02:07:34.211438 [ 16758 ] {4ff7a166-b3f5-4692-aa69-4be83e41de08} executeQuery: Code: 57. DB::Exception: Table test_15.ttl_00933_1 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51386) (comment: 00933_ttl_simple.sql) (query 26, line 48) (in query: create table ttl_00933_1 (d DateTime, a Int) engine = MergeTree order by tuple() partition by tuple() ttl d + interval 1 day settings remove_empty_parts = 0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:07:34.222971 [ 16758 ] {} TCPHandler: Code: 57. DB::Exception: Table test_15.ttl_00933_1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:07:34.694422 [ 6166 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778c58 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168167bf 10. /build/src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000001680ff45 11. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:07:34.699549 [ 6166 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x0000000016810069 5. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 6. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 2025.07.13 02:07:34.867175 [ 16756 ] {911db147-f1e9-4d12-bb21-f6bbeb7fa382} 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]:54396) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/FunctionSQLJSON.h:182: DB::FunctionSQLJSONHelpers::Executor>, DB::SimdJSONParser>::run(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int, unsigned int, bool) @ 0x0000000009fd176d 5. /build/src/Functions/FunctionSQLJSON.h:254: DB::FunctionSQLJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fd0c55 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:07:34.903686 [ 16756 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/FunctionSQLJSON.h:182: DB::FunctionSQLJSONHelpers::Executor>, DB::SimdJSONParser>::run(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int, unsigned int, bool) @ 0x0000000009fd176d 5. /build/src/Functions/FunctionSQLJSON.h:254: DB::FunctionSQLJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fd0c55 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:07:35.050643 [ 16756 ] {53528b18-1c41-4031-97ca-1eacde22a3d1} 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]:54396) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/FunctionSQLJSON.h:182: DB::FunctionSQLJSONHelpers::Executor>, DB::SimdJSONParser>::run(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int, unsigned int, bool) @ 0x0000000009fd176d 5. /build/src/Functions/FunctionSQLJSON.h:254: DB::FunctionSQLJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fd0c55 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:07:35.066359 [ 16756 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/FunctionSQLJSON.h:182: DB::FunctionSQLJSONHelpers::Executor>, DB::SimdJSONParser>::run(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int, unsigned int, bool) @ 0x0000000009fd176d 5. /build/src/Functions/FunctionSQLJSON.h:254: DB::FunctionSQLJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fd0c55 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:07:35.326076 [ 5018 ] {cc008f26-895e-4dd4-a26e-88cb165543de} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'array_1' to function 'arrayJaccardIndex'. Expected: Array, got: String: In scope SELECT 'a' AS arr1, 2 AS arr2, round(arrayJaccardIndex(arr1, arr2), 2). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42510) (comment: 02737_arrayJaccardIndex.sql) (query 2, line 3) (in query: SELECT 'a' AS arr1, 2 AS arr2, round(arrayJaccardIndex(arr1, arr2), 2);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/array/arrayJaccardIndex.cpp:90: DB::FunctionArrayJaccardIndex::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f4b4e06 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:07:35.333874 [ 5018 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'array_1' to function 'arrayJaccardIndex'. Expected: Array, got: String: In scope SELECT 'a' AS arr1, 2 AS arr2, round(arrayJaccardIndex(arr1, arr2), 2). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/array/arrayJaccardIndex.cpp:90: DB::FunctionArrayJaccardIndex::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f4b4e06 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:07:35.666422 [ 5018 ] {2fb4f93b-9da8-4370-aac5-8ad207f5bc84} executeQuery: Code: 43. DB::Exception: array aggregate functions cannot be performed on two empty arrays: In scope SELECT [] AS arr1, [] AS arr2, round(arrayJaccardIndex(arr1, arr2), 2). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42510) (comment: 02737_arrayJaccardIndex.sql) (query 3, line 4) (in query: SELECT [] AS arr1, [] AS arr2, round(arrayJaccardIndex(arr1, arr2), 2);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/array/arrayJaccardIndex.cpp:70: void DB::FunctionArrayJaccardIndex::vectorWithEmptyIntersect(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&) @ 0x000000000f4b51b5 5. /build/src/Functions/array/arrayJaccardIndex.cpp:136: DB::FunctionArrayJaccardIndex::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f4b4870 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:07:35.674162 [ 5018 ] {} TCPHandler: Code: 43. DB::Exception: array aggregate functions cannot be performed on two empty arrays: In scope SELECT [] AS arr1, [] AS arr2, round(arrayJaccardIndex(arr1, arr2), 2). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/array/arrayJaccardIndex.cpp:70: void DB::FunctionArrayJaccardIndex::vectorWithEmptyIntersect(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&) @ 0x000000000f4b51b5 5. /build/src/Functions/array/arrayJaccardIndex.cpp:136: DB::FunctionArrayJaccardIndex::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f4b4870 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:07:35.802998 [ 4278 ] {897215ac-fde3-4e9c-b97f-349b5fa29cfd::all_1_1_0_7} MutatePlainMergeTreeTask: Code: 190. DB::Exception: Elements '[100, 200]' and '['a', 'b', 'c']' of Nested data structure (Array columns) have different array sizes (2 and 3 respectively) on row 0: while executing 'FUNCTION validateNestedArraySizes(equals(id, 0) : 13, [100, 200] :: 5, ['a', 'b', 'c'] :: 6, [10, 20, 30] :: 7) -> validateNestedArraySizes(equals(id, 0), [100, 200], ['a', 'b', 'c'], [10, 20, 30]) UInt8 : 4'. (SIZES_OF_ARRAYS_DONT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:07:35.822612 [ 4278 ] {897215ac-fde3-4e9c-b97f-349b5fa29cfd::all_1_1_0_7} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 190. DB::Exception: Elements '[100, 200]' and '['a', 'b', 'c']' of Nested data structure (Array columns) have different array sizes (2 and 3 respectively) on row 0: while executing 'FUNCTION validateNestedArraySizes(equals(id, 0) : 13, [100, 200] :: 5, ['a', 'b', 'c'] :: 6, [10, 20, 30] :: 7) -> validateNestedArraySizes(equals(id, 0), [100, 200], ['a', 'b', 'c'], [10, 20, 30]) UInt8 : 4'. (SIZES_OF_ARRAYS_DONT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, unsigned long&, unsigned long&, unsigned long&) @ 0x000000000e8575f9 4. /build/src/Functions/validateNestedArraySizes.cpp:108: DB::FunctionValidateNestedArraySizes::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e857365 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 15. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 16. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 17. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000168e1018 18. /build/src/Storages/MergeTree/MutateTask.cpp:1247: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x000000001644d88e 19. /build/src/Storages/MergeTree/MutateTask.cpp:1162: DB::PartMergerWriter::execute() @ 0x0000000016465874 20. /build/src/Storages/MergeTree/MutateTask.cpp:1741: DB::MutateSomePartColumnsTask::executeStep() @ 0x00000000164660f6 21. /build/src/Storages/MergeTree/MutateTask.cpp:2113: DB::MutateTask::execute() @ 0x000000001644fd0f 22. /build/src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x0000000016594cb8 23. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 28. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:07:35.824183 [ 6614 ] {bf9a14e3-f131-40a7-ba65-c9e6204a8580} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_7.txt' with part 'all_1_1_0_6' reason: 'Code: 190. DB::Exception: Elements '[100, 200]' and '['a', 'b', 'c']' of Nested data structure (Array columns) have different array sizes (2 and 3 respectively) on row 0: while executing 'FUNCTION validateNestedArraySizes(equals(id, 0) : 13, [100, 200] :: 5, ['a', 'b', 'c'] :: 6, [10, 20, 30] :: 7) -> validateNestedArraySizes(equals(id, 0), [100, 200], ['a', 'b', 'c'], [10, 20, 30]) UInt8 : 4'. (SIZES_OF_ARRAYS_DONT_MATCH) (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/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Storages/MergeTree/MergeTreeMutationStatus.cpp:33: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x000000001639ba0e 2. /build/src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000001655dce8 3. /build/src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000001655ed84 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd3ec 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 . (UNFINISHED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51482) (comment: 01788_update_nested_type_subcolumn_check.sql) (query 15, line 32) (in query: alter table test_wide_nested update `info.id` = [100,200], `info.age` = [10,20,30], `info.name` = ['a','b','c'] where id = 0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&, String&&) @ 0x000000001639bb59 4. /build/src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x000000001639ba6d 5. /build/src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000001655dce8 6. /build/src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000001655ed84 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd3ec 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:07:35.827730 [ 4278 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {897215ac-fde3-4e9c-b97f-349b5fa29cfd::all_1_1_0_7}: Code: 190. DB::Exception: Elements '[100, 200]' and '['a', 'b', 'c']' of Nested data structure (Array columns) have different array sizes (2 and 3 respectively) on row 0: while executing 'FUNCTION validateNestedArraySizes(equals(id, 0) : 13, [100, 200] :: 5, ['a', 'b', 'c'] :: 6, [10, 20, 30] :: 7) -> validateNestedArraySizes(equals(id, 0), [100, 200], ['a', 'b', 'c'], [10, 20, 30]) UInt8 : 4'. (SIZES_OF_ARRAYS_DONT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, unsigned long&, unsigned long&, unsigned long&) @ 0x000000000e8575f9 4. /build/src/Functions/validateNestedArraySizes.cpp:108: DB::FunctionValidateNestedArraySizes::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e857365 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 15. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 16. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 17. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000168e1018 18. /build/src/Storages/MergeTree/MutateTask.cpp:1247: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x000000001644d88e 19. /build/src/Storages/MergeTree/MutateTask.cpp:1162: DB::PartMergerWriter::execute() @ 0x0000000016465874 20. /build/src/Storages/MergeTree/MutateTask.cpp:1741: DB::MutateSomePartColumnsTask::executeStep() @ 0x00000000164660f6 21. /build/src/Storages/MergeTree/MutateTask.cpp:2113: DB::MutateTask::execute() @ 0x000000001644fd0f 22. /build/src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x0000000016594cb8 23. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 28. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:07:35.833272 [ 6614 ] {} TCPHandler: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_7.txt' with part 'all_1_1_0_6' reason: 'Code: 190. DB::Exception: Elements '[100, 200]' and '['a', 'b', 'c']' of Nested data structure (Array columns) have different array sizes (2 and 3 respectively) on row 0: while executing 'FUNCTION validateNestedArraySizes(equals(id, 0) : 13, [100, 200] :: 5, ['a', 'b', 'c'] :: 6, [10, 20, 30] :: 7) -> validateNestedArraySizes(equals(id, 0), [100, 200], ['a', 'b', 'c'], [10, 20, 30]) UInt8 : 4'. (SIZES_OF_ARRAYS_DONT_MATCH) (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/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Storages/MergeTree/MergeTreeMutationStatus.cpp:33: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x000000001639ba0e 2. /build/src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000001655dce8 3. /build/src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000001655ed84 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd3ec 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 . (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&, String&&) @ 0x000000001639bb59 4. /build/src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x000000001639ba6d 5. /build/src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000001655dce8 6. /build/src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000001655ed84 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd3ec 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:07:36.028750 [ 5018 ] {71e19f34-9053-4d59-916b-5d9aed747bb1} executeQuery: Code: 386. DB::Exception: There is no subtype for types String, UInt8 because some of them are String/FixedString and some of them are not: In scope SELECT ['1', '2'] AS arr1, [1, 2] AS arr2, round(arrayJaccardIndex(arr1, arr2), 2). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42510) (comment: 02737_arrayJaccardIndex.sql) (query 4, line 5) (in query: SELECT ['1', '2'] AS arr1, [1,2] AS arr2, round(arrayJaccardIndex(arr1, arr2), 2);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000009fd29ed 3. /build/src/DataTypes/getMostSubtype.cpp:53: DB::getMostSubtype(std::vector, std::allocator>> const&, bool, bool)::$_0::operator()(String const&) const @ 0x0000000013b9a152 4. /build/src/DataTypes/getMostSubtype.cpp:232: DB::getMostSubtype(std::vector, std::allocator>> const&, bool, bool) @ 0x0000000013b9942c 5. /build/src/Functions/array/arrayIntersect.cpp:206: DB::FunctionArrayIntersect::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000f457078 6. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Functions/array/arrayJaccardIndex.cpp:112: DB::FunctionArrayJaccardIndex::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f4b447b 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 27. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 28. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 2025.07.13 02:07:36.060369 [ 5018 ] {} TCPHandler: Code: 386. DB::Exception: There is no subtype for types String, UInt8 because some of them are String/FixedString and some of them are not: In scope SELECT ['1', '2'] AS arr1, [1, 2] AS arr2, round(arrayJaccardIndex(arr1, arr2), 2). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000009fd29ed 3. /build/src/DataTypes/getMostSubtype.cpp:53: DB::getMostSubtype(std::vector, std::allocator>> const&, bool, bool)::$_0::operator()(String const&) const @ 0x0000000013b9a152 4. /build/src/DataTypes/getMostSubtype.cpp:232: DB::getMostSubtype(std::vector, std::allocator>> const&, bool, bool) @ 0x0000000013b9942c 5. /build/src/Functions/array/arrayIntersect.cpp:206: DB::FunctionArrayIntersect::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000f457078 6. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Functions/array/arrayJaccardIndex.cpp:112: DB::FunctionArrayJaccardIndex::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f4b447b 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 27. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 28. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 2025.07.13 02:07:36.538015 [ 6619 ] {ba146fbf-f2b9-4b79-8864-5bfc5e34d214} 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]:42456) (comment: 01072_optimize_skip_unused_shards_const_expr_eval.sql) (query 14, line 19) (in query: select * from dist_01072 where key=value;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Storages/StorageDistributed.cpp:1563: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000015c804bb 5. /build/src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000015c7f18d 6. /build/src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000148b5e3b 7. /build/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&) @ 0x00000000148ad029 8. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 9. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:07:36.559016 [ 6619 ] {} TCPHandler: Code: 507. DB::Exception: Sharding key modulo(key, 2) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Storages/StorageDistributed.cpp:1563: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000015c804bb 5. /build/src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000015c7f18d 6. /build/src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000148b5e3b 7. /build/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&) @ 0x00000000148ad029 8. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 9. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:07:36.888913 [ 6619 ] {1c3bf792-6b9e-4d30-8ef5-63229dc10db4} 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]:42456) (comment: 01072_optimize_skip_unused_shards_const_expr_eval.sql) (query 15, line 20) (in query: select * from dist_01072 where key=toInt32(value);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Storages/StorageDistributed.cpp:1563: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000015c804bb 5. /build/src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000015c7f18d 6. /build/src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000148b5e3b 7. /build/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&) @ 0x00000000148ad029 8. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 9. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:07:36.913996 [ 6619 ] {} TCPHandler: Code: 507. DB::Exception: Sharding key modulo(key, 2) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Storages/StorageDistributed.cpp:1563: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000015c804bb 5. /build/src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000015c7f18d 6. /build/src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000148b5e3b 7. /build/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&) @ 0x00000000148ad029 8. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 9. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:07:36.915876 [ 4273 ] {897215ac-fde3-4e9c-b97f-349b5fa29cfd::all_1_1_0_7} MutatePlainMergeTreeTask: Code: 236. DB::Exception: Cancelled mutating parts. (ABORTED) (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:07:36.964043 [ 4273 ] {897215ac-fde3-4e9c-b97f-349b5fa29cfd::all_1_1_0_7} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 236. DB::Exception: Cancelled mutating parts. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Storages/MergeTree/MutateTask.cpp:1106: DB::MutationContext::checkOperationIsNotCanceled() const @ 0x000000001645ec23 5. /build/src/Storages/MergeTree/MutateTask.cpp:2111: DB::MutateTask::execute() @ 0x000000001644fd06 6. /build/src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x0000000016594cb8 7. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 8. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:07:39.365321 [ 6166 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000013779f8b 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000137794b8 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778c58 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168167bf 10. /build/src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000001680ff45 11. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:07:39.369707 [ 6166 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x0000000016810069 5. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 6. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 2025.07.13 02:07:39.927094 [ 4275 ] {fb2c287d-4fc3-4677-91bf-6a73f38c0979::all_1_1_0_3} MutatePlainMergeTreeTask: Code: 190. DB::Exception: Elements '[10, 20, 30]' and 'info.age' of Nested data structure (Array columns) have different array sizes (3 and 2 respectively) on row 1: while executing 'FUNCTION validateNestedArraySizes(equals(id, 1) : 9, [10, 20, 30] :: 4, info.age : 2) -> validateNestedArraySizes(equals(id, 1), [10, 20, 30], info.age) UInt8 : 3'. (SIZES_OF_ARRAYS_DONT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:07:39.935013 [ 6614 ] {c2d83a39-411f-4aa6-9781-233b5e9999f2} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_3.txt' with part 'all_1_1_0_2' reason: 'Code: 190. DB::Exception: Elements '[10, 20, 30]' and 'info.age' of Nested data structure (Array columns) have different array sizes (3 and 2 respectively) on row 1: while executing 'FUNCTION validateNestedArraySizes(equals(id, 1) : 9, [10, 20, 30] :: 4, info.age : 2) -> validateNestedArraySizes(equals(id, 1), [10, 20, 30], info.age) UInt8 : 3'. (SIZES_OF_ARRAYS_DONT_MATCH) (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/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Storages/MergeTree/MergeTreeMutationStatus.cpp:33: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x000000001639ba0e 2. /build/src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000001655dce8 3. /build/src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000001655ed84 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd3ec 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 . (UNFINISHED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51482) (comment: 01788_update_nested_type_subcolumn_check.sql) (query 25, line 57) (in query: alter table test_wide_nested update `info.id` = [100,200,300], `info.age` = [10,20,30] where id = 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&, String&&) @ 0x000000001639bb59 4. /build/src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x000000001639ba6d 5. /build/src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000001655dce8 6. /build/src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000001655ed84 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd3ec 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:07:39.931636 [ 4275 ] {fb2c287d-4fc3-4677-91bf-6a73f38c0979::all_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 190. DB::Exception: Elements '[10, 20, 30]' and 'info.age' of Nested data structure (Array columns) have different array sizes (3 and 2 respectively) on row 1: while executing 'FUNCTION validateNestedArraySizes(equals(id, 1) : 9, [10, 20, 30] :: 4, info.age : 2) -> validateNestedArraySizes(equals(id, 1), [10, 20, 30], info.age) UInt8 : 3'. (SIZES_OF_ARRAYS_DONT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, unsigned long&, unsigned long&, unsigned long&) @ 0x000000000e8575f9 4. /build/src/Functions/validateNestedArraySizes.cpp:108: DB::FunctionValidateNestedArraySizes::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e857365 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 15. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 16. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 17. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000168e1018 18. /build/src/Storages/MergeTree/MutateTask.cpp:1247: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x000000001644d88e 19. /build/src/Storages/MergeTree/MutateTask.cpp:1162: DB::PartMergerWriter::execute() @ 0x0000000016465874 20. /build/src/Storages/MergeTree/MutateTask.cpp:1741: DB::MutateSomePartColumnsTask::executeStep() @ 0x00000000164660f6 21. /build/src/Storages/MergeTree/MutateTask.cpp:2113: DB::MutateTask::execute() @ 0x000000001644fd0f 22. /build/src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x0000000016594cb8 23. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 28. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:07:39.938997 [ 4275 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {fb2c287d-4fc3-4677-91bf-6a73f38c0979::all_1_1_0_3}: Code: 190. DB::Exception: Elements '[10, 20, 30]' and 'info.age' of Nested data structure (Array columns) have different array sizes (3 and 2 respectively) on row 1: while executing 'FUNCTION validateNestedArraySizes(equals(id, 1) : 9, [10, 20, 30] :: 4, info.age : 2) -> validateNestedArraySizes(equals(id, 1), [10, 20, 30], info.age) UInt8 : 3'. (SIZES_OF_ARRAYS_DONT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, unsigned long&, unsigned long&, unsigned long&) @ 0x000000000e8575f9 4. /build/src/Functions/validateNestedArraySizes.cpp:108: DB::FunctionValidateNestedArraySizes::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e857365 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 15. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 16. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 17. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000168e1018 18. /build/src/Storages/MergeTree/MutateTask.cpp:1247: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x000000001644d88e 19. /build/src/Storages/MergeTree/MutateTask.cpp:1162: DB::PartMergerWriter::execute() @ 0x0000000016465874 20. /build/src/Storages/MergeTree/MutateTask.cpp:1741: DB::MutateSomePartColumnsTask::executeStep() @ 0x00000000164660f6 21. /build/src/Storages/MergeTree/MutateTask.cpp:2113: DB::MutateTask::execute() @ 0x000000001644fd0f 22. /build/src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x0000000016594cb8 23. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 28. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:07:39.956863 [ 6614 ] {} TCPHandler: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_3.txt' with part 'all_1_1_0_2' reason: 'Code: 190. DB::Exception: Elements '[10, 20, 30]' and 'info.age' of Nested data structure (Array columns) have different array sizes (3 and 2 respectively) on row 1: while executing 'FUNCTION validateNestedArraySizes(equals(id, 1) : 9, [10, 20, 30] :: 4, info.age : 2) -> validateNestedArraySizes(equals(id, 1), [10, 20, 30], info.age) UInt8 : 3'. (SIZES_OF_ARRAYS_DONT_MATCH) (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/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Storages/MergeTree/MergeTreeMutationStatus.cpp:33: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x000000001639ba0e 2. /build/src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000001655dce8 3. /build/src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000001655ed84 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd3ec 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 . (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&, String&&) @ 0x000000001639bb59 4. /build/src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x000000001639ba6d 5. /build/src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000001655dce8 6. /build/src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000001655ed84 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd3ec 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:07:40.293633 [ 6619 ] {278acfef-f837-46ec-a6c9-978f1e38019d} 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]:42456) (comment: 01072_optimize_skip_unused_shards_const_expr_eval.sql) (query 21, line 27) (in query: select * from dist_01072 where key=value;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Storages/StorageDistributed.cpp:1563: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000015c804bb 5. /build/src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000015c7f18d 6. /build/src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000148b5e3b 7. /build/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&) @ 0x00000000148ad029 8. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 9. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:07:40.301372 [ 6619 ] {} TCPHandler: Code: 507. DB::Exception: Sharding key modulo(key, 2) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Storages/StorageDistributed.cpp:1563: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000015c804bb 5. /build/src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000015c7f18d 6. /build/src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000148b5e3b 7. /build/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&) @ 0x00000000148ad029 8. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 9. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:07:40.401002 [ 6619 ] {1a80fdda-04e9-45af-9317-a41045a2d72d} 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]:42456) (comment: 01072_optimize_skip_unused_shards_const_expr_eval.sql) (query 22, line 28) (in query: select * from dist_01072 where key=toInt32(value);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Storages/StorageDistributed.cpp:1563: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000015c804bb 5. /build/src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000015c7f18d 6. /build/src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000148b5e3b 7. /build/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&) @ 0x00000000148ad029 8. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 9. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:07:40.431743 [ 6619 ] {} TCPHandler: Code: 507. DB::Exception: Sharding key modulo(key, 2) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Storages/StorageDistributed.cpp:1563: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000015c804bb 5. /build/src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000015c7f18d 6. /build/src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000148b5e3b 7. /build/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&) @ 0x00000000148ad029 8. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 9. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:07:42.144676 [ 16756 ] {52202efa-7d83-462a-a546-f22a14981b5d} executeQuery: Code: 395. DB::Exception: Expected guid as argument: while executing 'FUNCTION if(_CAST(1_UInt8, 'UInt8'_String) :: 1, toString(throwIf(1_Bool, 'Expected guid as argument'_String)) :: 3, _CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String) :: 4) -> if(_CAST(1_UInt8, 'UInt8'_String), toString(throwIf(1_Bool, 'Expected guid as argument'_String)), _CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String)) Nullable(String) : 5'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54396) (comment: 02366_kql_func_string.sql) (query 197, line 226) (in query: print base64_encode_fromguid(dynamic(null));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::Exception::createRuntime(int, String const&) @ 0x000000000e73218c 3. /build/src/Functions/throwIf.cpp:150: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e730438 4. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 5. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 6. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 7. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 8. /build/src/Functions/IFunction.cpp:513: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c80999 9. /build/src/Columns/ColumnFunction.cpp:372: DB::ColumnFunction::reduce() const @ 0x00000000159033b7 10. /build/src/Columns/ColumnFunction.cpp:361: DB::ColumnFunction::reduce() const @ 0x0000000015903155 11. /build/src/Columns/MaskOperations.cpp:299: DB::executeColumnIfNeeded(DB::ColumnWithTypeAndName&, bool) @ 0x0000000015c00202 12. /build/src/Functions/if.cpp:1156: DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000013fd358f 13. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 14. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 17. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 18. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 19. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 20. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 21. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 22. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 23. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 24. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 25. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 26. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 28. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:07:42.169370 [ 16756 ] {} TCPHandler: Code: 395. DB::Exception: Expected guid as argument: while executing 'FUNCTION if(_CAST(1_UInt8, 'UInt8'_String) :: 1, toString(throwIf(1_Bool, 'Expected guid as argument'_String)) :: 3, _CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String) :: 4) -> if(_CAST(1_UInt8, 'UInt8'_String), toString(throwIf(1_Bool, 'Expected guid as argument'_String)), _CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String)) Nullable(String) : 5'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::Exception::createRuntime(int, String const&) @ 0x000000000e73218c 3. /build/src/Functions/throwIf.cpp:150: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e730438 4. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 5. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 6. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 7. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 8. /build/src/Functions/IFunction.cpp:513: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c80999 9. /build/src/Columns/ColumnFunction.cpp:372: DB::ColumnFunction::reduce() const @ 0x00000000159033b7 10. /build/src/Columns/ColumnFunction.cpp:361: DB::ColumnFunction::reduce() const @ 0x0000000015903155 11. /build/src/Columns/MaskOperations.cpp:299: DB::executeColumnIfNeeded(DB::ColumnWithTypeAndName&, bool) @ 0x0000000015c00202 12. /build/src/Functions/if.cpp:1156: DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000013fd358f 13. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 14. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 17. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 18. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 19. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 20. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 21. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 22. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 23. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 24. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 25. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 26. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 28. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:07:42.439162 [ 16756 ] {696e8920-9878-4267-9ffd-c3621a0682aa} executeQuery: Code: 395. DB::Exception: Expected guid as argument: while executing 'FUNCTION throwIf(1_Bool :: 1, 'Expected guid as argument'_String :: 2) -> throwIf(1_Bool, 'Expected guid as argument'_String) UInt8 : 3'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54396) (comment: 02366_kql_func_string.sql) (query 198, line 227) (in query: print base64_encode_fromguid("abcd1231");), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::Exception::createRuntime(int, String const&) @ 0x000000000e73218c 3. /build/src/Functions/throwIf.cpp:150: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e730438 4. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 5. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 6. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 7. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 8. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 9. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 10. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 11. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 12. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 13. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 14. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 15. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 16. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 17. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 20. ? @ 0x00007f7210eb6ac3 21. ? @ 0x00007f7210f48850 2025.07.13 02:07:42.460958 [ 16756 ] {} TCPHandler: Code: 395. DB::Exception: Expected guid as argument: while executing 'FUNCTION throwIf(1_Bool :: 1, 'Expected guid as argument'_String :: 2) -> throwIf(1_Bool, 'Expected guid as argument'_String) UInt8 : 3'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::Exception::createRuntime(int, String const&) @ 0x000000000e73218c 3. /build/src/Functions/throwIf.cpp:150: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e730438 4. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 5. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 6. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 7. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 8. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 9. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 10. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 11. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 12. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 13. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 14. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 15. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 16. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 17. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 20. ? @ 0x00007f7210eb6ac3 21. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:07:44.726380 [ 6619 ] {937547d5-c377-46ad-b7aa-22cbf577da96} 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]:42456) (comment: 01072_optimize_skip_unused_shards_const_expr_eval.sql) (query 29, line 37) (in query: select * from dist_01072 where key=value;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Storages/StorageDistributed.cpp:1563: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000015c804bb 5. /build/src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000015c7f18d 6. /build/src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000148b5e3b 7. /build/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&) @ 0x00000000148ad029 8. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 9. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:07:44.737851 [ 6619 ] {} TCPHandler: Code: 507. DB::Exception: Sharding key modulo(key, 2) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Storages/StorageDistributed.cpp:1563: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000015c804bb 5. /build/src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000015c7f18d 6. /build/src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000148b5e3b 7. /build/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&) @ 0x00000000148ad029 8. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 9. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:07:44.818141 [ 6619 ] {0f2a2b97-114d-4719-bb7e-96765cb02852} 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]:42456) (comment: 01072_optimize_skip_unused_shards_const_expr_eval.sql) (query 30, line 38) (in query: select * from dist_01072 where key=toInt32(value);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Storages/StorageDistributed.cpp:1563: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000015c804bb 5. /build/src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000015c7f18d 6. /build/src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000148b5e3b 7. /build/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&) @ 0x00000000148ad029 8. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 9. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:07:44.826656 [ 6619 ] {} TCPHandler: Code: 507. DB::Exception: Sharding key modulo(key, 2) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Storages/StorageDistributed.cpp:1563: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000015c804bb 5. /build/src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000015c7f18d 6. /build/src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000148b5e3b 7. /build/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&) @ 0x00000000148ad029 8. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 9. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:07:46.422388 [ 6611 ] {415a4b9b-24c4-41c9-8094-3f1f12ade58a} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42532) (comment: 02391_hashed_dictionary_shards.sql) (query 22, line 62) (in query: DROP DICTIONARY test_dictionary_10_shards_nullable;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833ede 5. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 7. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 10. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:07:46.453881 [ 6611 ] {} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833ede 5. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 7. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 10. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:07:46.496885 [ 6619 ] {cc319b2d-09e3-4780-8574-d8299f2a11f3} executeQuery: Code: 57. DB::Exception: Table test_5.dist_01072 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 01072_optimize_skip_unused_shards_const_expr_eval.sql) (in query: /* ddl_entry=query-0000000058 */ CREATE TABLE test_5.dist_01072 UUID 'a6b2605c-06ee-4687-b266-1de408f29c61' (`key` Int32, `value` LowCardinality(Nullable(Int32)), `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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 12. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:07:46.743449 [ 6619 ] {cc319b2d-09e3-4780-8574-d8299f2a11f3} executeQuery: Code: 57. DB::Exception: Table test_5.dist_01072 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42456) (comment: 01072_optimize_skip_unused_shards_const_expr_eval.sql) (query 34, line 43) (in query: create table dist_01072 (key Int, value LowCardinality(Nullable(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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 12. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:07:46.785029 [ 6619 ] {} TCPHandler: Code: 57. DB::Exception: Table test_5.dist_01072 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 12. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:07:48.434682 [ 16784 ] {3032eea7-63c9-46bc-8742-c69318f6695a} executeQuery: Code: 377. DB::Exception: Can't use [NOT] NULL modifier with Nullable type. (ILLEGAL_SYNTAX_FOR_DATA_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37956) (comment: 01269_create_with_null.sql) (query 9, line 23) (in query: CREATE TABLE data_null_error ( a Nullable(INT) NULL, b INT NOT NULL, c Nullable(INT) ) engine=Memory();), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:577: DB::InterpreterCreateQuery::getColumnType(DB::ASTColumnDeclaration const&, DB::LoadingStrictnessLevel, bool) @ 0x000000001480aa98 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:625: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000001480ac8f 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001480c764 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000001481759b 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:07:48.442700 [ 16784 ] {} TCPHandler: Code: 377. DB::Exception: Can't use [NOT] NULL modifier with Nullable type. (ILLEGAL_SYNTAX_FOR_DATA_TYPE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:577: DB::InterpreterCreateQuery::getColumnType(DB::ASTColumnDeclaration const&, DB::LoadingStrictnessLevel, bool) @ 0x000000001480aa98 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:625: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000001480ac8f 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001480c764 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000001481759b 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:07:48.474857 [ 16784 ] {7fc90768-8d1d-41a2-85cb-e9a5b7bb5388} executeQuery: Code: 377. DB::Exception: Can't use [NOT] NULL modifier with Nullable type. (ILLEGAL_SYNTAX_FOR_DATA_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37956) (comment: 01269_create_with_null.sql) (query 10, line 30) (in query: CREATE TABLE data_null_error ( a INT NULL, b Nullable(INT) NOT NULL, c Nullable(INT) ) engine=Memory();), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:577: DB::InterpreterCreateQuery::getColumnType(DB::ASTColumnDeclaration const&, DB::LoadingStrictnessLevel, bool) @ 0x000000001480aa98 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:625: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000001480ac8f 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001480c764 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000001481759b 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:07:48.489154 [ 16784 ] {} TCPHandler: Code: 377. DB::Exception: Can't use [NOT] NULL modifier with Nullable type. (ILLEGAL_SYNTAX_FOR_DATA_TYPE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:577: DB::InterpreterCreateQuery::getColumnType(DB::ASTColumnDeclaration const&, DB::LoadingStrictnessLevel, bool) @ 0x000000001480aa98 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:625: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000001480ac8f 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001480c764 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000001481759b 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:07:49.905261 [ 16784 ] {be7c92c9-7dfb-4fed-b996-dd36b0bc8555} executeQuery: Code: 43. DB::Exception: Nested type Array(UInt8) cannot be inside Nullable type. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37956) (comment: 01269_create_with_null.sql) (query 19, line 56) (in query: CREATE TABLE cannot_be_nullable (n Int8, a Array(UInt8)) ENGINE=Memory;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/DataTypes/DataTypeNullable.cpp:31: DB::DataTypeNullable::DataTypeNullable(std::shared_ptr const&) @ 0x0000000013b1b628 5. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], std::shared_ptr const&, 0>(std::allocator const&, std::shared_ptr const&) @ 0x00000000116f59fc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::makeNullable(std::shared_ptr const&) @ 0x0000000013b1c399 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:583: DB::InterpreterCreateQuery::getColumnType(DB::ASTColumnDeclaration const&, DB::LoadingStrictnessLevel, bool) @ 0x000000001480a827 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:625: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000001480ac8f 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001480c764 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000001481759b 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 14. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 15. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 20. ? @ 0x00007f7210eb6ac3 21. ? @ 0x00007f7210f48850 2025.07.13 02:07:49.932369 [ 16784 ] {} TCPHandler: Code: 43. DB::Exception: Nested type Array(UInt8) cannot be inside Nullable type. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/DataTypes/DataTypeNullable.cpp:31: DB::DataTypeNullable::DataTypeNullable(std::shared_ptr const&) @ 0x0000000013b1b628 5. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], std::shared_ptr const&, 0>(std::allocator const&, std::shared_ptr const&) @ 0x00000000116f59fc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::makeNullable(std::shared_ptr const&) @ 0x0000000013b1c399 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:583: DB::InterpreterCreateQuery::getColumnType(DB::ASTColumnDeclaration const&, DB::LoadingStrictnessLevel, bool) @ 0x000000001480a827 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:625: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000001480ac8f 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001480c764 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000001481759b 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 14. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 15. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 20. ? @ 0x00007f7210eb6ac3 21. ? @ 0x00007f7210f48850 2025.07.13 02:07:50.620974 [ 6608 ] {895138b9-eb2e-4632-95af-458280a3a117} executeQuery: Code: 35. DB::Exception: Number of arguments for function "and" should be at least 2: passed 1: In scope SELECT b FROM set_index__fuzz_41 WHERE and(b = 256) SETTINGS force_data_skipping_indices = 'b_set', optimize_move_to_prewhere = 0, max_parallel_replicas = 2, parallel_replicas_for_non_replicated_merge_tree = 1, enable_parallel_replicas = 2. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37718) (comment: 02861_index_set_incorrect_args.sql) (query 4, line 5) (in query: SELECT b FROM set_index__fuzz_41 WHERE and(b = 256) SETTINGS force_data_skipping_indices = 'b_set', optimize_move_to_prewhere = 0, max_parallel_replicas=2, parallel_replicas_for_non_replicated_merge_tree=1, enable_parallel_replicas=2;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000009fb386b 4. /build/src/Functions/FunctionsLogical.cpp:519: DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000012cb0210 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3236a 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:07:50.631940 [ 6608 ] {} TCPHandler: Code: 35. DB::Exception: Number of arguments for function "and" should be at least 2: passed 1: In scope SELECT b FROM set_index__fuzz_41 WHERE and(b = 256) SETTINGS force_data_skipping_indices = 'b_set', optimize_move_to_prewhere = 0, max_parallel_replicas = 2, parallel_replicas_for_non_replicated_merge_tree = 1, enable_parallel_replicas = 2. (TOO_FEW_ARGUMENTS_FOR_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000009fb386b 4. /build/src/Functions/FunctionsLogical.cpp:519: DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000012cb0210 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3236a 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:07:54.641292 [ 16756 ] {9ef529ba-9e71-421f-9ba5-96c7365886fc} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 's' to function 'splitByChar'. Expected: String, got: UInt8: In scope SELECT if((length(splitByChar('.', 42)) > 4) OR (length(splitByChar('.', 42)) < 1) OR (match(42, '.*[a-zA-Z]+.*') = 1), toDecimal128OrNull('NULL', 0), toDecimal128OrNull(substring(arrayStringConcat(arrayMap(x -> leftPad(x, 8, '0'), arrayMap(x -> if(empty(x), '0', x), arrayResize(splitByChar('.', 42), 4)))), 8), 0)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54396) (comment: 02366_kql_func_string.sql) (query 246, line 275) (in query: print parse_version(42);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/FunctionTokens.h:204: DB::FunctionTokens::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e5f4e4d 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4e8a9 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 27. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 28. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 2025.07.13 02:07:54.665689 [ 16756 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 's' to function 'splitByChar'. Expected: String, got: UInt8: In scope SELECT if((length(splitByChar('.', 42)) > 4) OR (length(splitByChar('.', 42)) < 1) OR (match(42, '.*[a-zA-Z]+.*') = 1), toDecimal128OrNull('NULL', 0), toDecimal128OrNull(substring(arrayStringConcat(arrayMap(x -> leftPad(x, 8, '0'), arrayMap(x -> if(empty(x), '0', x), arrayResize(splitByChar('.', 42), 4)))), 8), 0)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/FunctionTokens.h:204: DB::FunctionTokens::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e5f4e4d 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4e8a9 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 27. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 28. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 2025.07.13 02:07:57.105227 [ 16758 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000013779f8b 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000137794b8 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778bc3 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678d325 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:07:57.326075 [ 4896 ] {9b803133-4d54-4190-9a41-f8e052761772} executeQuery: Code: 36. DB::Exception: Argument 'format/NOSIGN' must be a literal with type String, got Array. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37788) (comment: 02245_s3_schema_desc.sql) (query 9, line 14) (in query: SELECT * FROM s3(decodeURLComponent(NULL), [NULL]);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>, std::basic_string_view>>(int, FormatStringHelperImpl::type, std::type_identity>>::type, std::type_identity>>::type>, String const&, std::basic_string_view>&&, std::basic_string_view>&&) @ 0x0000000015f7596b 4. /build/src/Storages/checkAndGetLiteralArgument.cpp:39: String DB::checkAndGetLiteralArgument(DB::ASTLiteral const&, String const&) @ 0x0000000015f75106 5. /build/src/Storages/checkAndGetLiteralArgument.cpp:22: String DB::checkAndGetLiteralArgument(std::shared_ptr const&, String const&) @ 0x0000000015f74e6f 6. /build/src/Storages/ObjectStorage/S3/Configuration.cpp:279: DB::StorageS3Configuration::fromAST(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool) @ 0x00000000132609c0 7. /build/src/Storages/ObjectStorage/StorageObjectStorage.cpp:616: DB::StorageObjectStorage::Configuration::initialize(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool, std::shared_ptr) @ 0x00000000131aef35 8. /build/src/TableFunctions/TableFunctionObjectStorage.h:137: DB::TableFunctionObjectStorage::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x0000000011763273 9. /build/src/TableFunctions/TableFunctionObjectStorage.cpp:105: DB::TableFunctionObjectStorage::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000117646cc 10. /build/src/TableFunctions/ITableFunctionCluster.h:59: DB::ITableFunctionCluster>::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000001179a7e4 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3bbcc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:07:57.382376 [ 4896 ] {} TCPHandler: Code: 36. DB::Exception: Argument 'format/NOSIGN' must be a literal with type String, got Array. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>, std::basic_string_view>>(int, FormatStringHelperImpl::type, std::type_identity>>::type, std::type_identity>>::type>, String const&, std::basic_string_view>&&, std::basic_string_view>&&) @ 0x0000000015f7596b 4. /build/src/Storages/checkAndGetLiteralArgument.cpp:39: String DB::checkAndGetLiteralArgument(DB::ASTLiteral const&, String const&) @ 0x0000000015f75106 5. /build/src/Storages/checkAndGetLiteralArgument.cpp:22: String DB::checkAndGetLiteralArgument(std::shared_ptr const&, String const&) @ 0x0000000015f74e6f 6. /build/src/Storages/ObjectStorage/S3/Configuration.cpp:279: DB::StorageS3Configuration::fromAST(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool) @ 0x00000000132609c0 7. /build/src/Storages/ObjectStorage/StorageObjectStorage.cpp:616: DB::StorageObjectStorage::Configuration::initialize(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool, std::shared_ptr) @ 0x00000000131aef35 8. /build/src/TableFunctions/TableFunctionObjectStorage.h:137: DB::TableFunctionObjectStorage::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x0000000011763273 9. /build/src/TableFunctions/TableFunctionObjectStorage.cpp:105: DB::TableFunctionObjectStorage::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000117646cc 10. /build/src/TableFunctions/ITableFunctionCluster.h:59: DB::ITableFunctionCluster>::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000001179a7e4 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3bbcc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:07:57.601584 [ 16784 ] {f32bfea9-2dcf-404b-8300-7252f415af0e} executeQuery: Code: 57. DB::Exception: Table test_dk755uh5.t_vertical_merges already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02286_vertical_merges_missed_column.sql) (in query: /* ddl_entry=query-0000000004 */ CREATE TABLE test_dk755uh5.t_vertical_merges UUID '0122d4ec-e282-4b59-b311-6c3070a50234' (`a` Array(Int16), `b` Int8) ENGINE = MergeTree ORDER BY tuple() SETTINGS vertical_merge_algorithm_min_columns_to_activate = 1, vertical_merge_algorithm_min_rows_to_activate = 1, min_bytes_for_wide_part = 0, index_granularity = 47164, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 329061256, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 10953602, merge_max_block_size = 17186, old_parts_lifetime = 119., prefer_fetch_merged_part_size_threshold = 8043454795, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 5338744, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 3, 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 = 47894, primary_key_compress_block_size = 28975, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 12. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:07:57.709364 [ 16784 ] {f32bfea9-2dcf-404b-8300-7252f415af0e} executeQuery: Code: 57. DB::Exception: Table test_dk755uh5.t_vertical_merges already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37796) (comment: 02286_vertical_merges_missed_column.sql) (query 8, line 22) (in query: CREATE TABLE t_vertical_merges (`a` Array(Int16), `b` Int8) ENGINE = MergeTree ORDER BY tuple() SETTINGS vertical_merge_algorithm_min_columns_to_activate = 1, vertical_merge_algorithm_min_rows_to_activate = 1, min_bytes_for_wide_part = 0, index_granularity = 47164, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 329061256, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 10953602, merge_max_block_size = 17186, old_parts_lifetime = 119., prefer_fetch_merged_part_size_threshold = 8043454795, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 5338744, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 3, 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 = 47894, primary_key_compress_block_size = 28975, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 12. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:07:57.758813 [ 16784 ] {} TCPHandler: Code: 57. DB::Exception: Table test_dk755uh5.t_vertical_merges already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 12. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:07:58.891580 [ 16756 ] {38ba8901-e512-47fa-b5d9-604cac12228e} executeQuery: Code: 43. DB::Exception: Illegal type UInt8 of argument of function empty: In scope SELECT if(empty(55) OR hasAll(splitByChar(' ', 55), ['']), arrayMap(x -> NULL, splitByChar(' ', '')), splitByChar(' ', 55)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54396) (comment: 02366_kql_func_string.sql) (query 259, line 289) (in query: print parse_command_line(55, 'windows');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/empty.cpp:149: DB::(anonymous namespace)::FunctionEmptyOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000b533ec7 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4e8a9 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 28. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 29. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 2025.07.13 02:07:58.919817 [ 16756 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type UInt8 of argument of function empty: In scope SELECT if(empty(55) OR hasAll(splitByChar(' ', 55), ['']), arrayMap(x -> NULL, splitByChar(' ', '')), splitByChar(' ', 55)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/empty.cpp:149: DB::(anonymous namespace)::FunctionEmptyOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000b533ec7 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4e8a9 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 28. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 29. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 2025.07.13 02:07:59.749568 [ 6532 ] {befbe4f2-ab6e-489d-b6be-ef93cd7fd71d} 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]:48844) (comment: 00926_adaptive_index_granularity_pk.sql) (in query: DROP DATABASE IF EXISTS test_2uq66vl0 SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:07:59.755354 [ 6532 ] {befbe4f2-ab6e-489d-b6be-ef93cd7fd71d} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:08:01.036642 [ 4888 ] {d6b943dc-998a-48af-86b7-0adc19aac1a4} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `x` in scope SELECT x FROM system.numbers LIMIT 1. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:43914) (comment: 02899_use_default_format_on_http_exception.sh) (in query: SELECT x FROM system.numbers LIMIT 1; ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000013f69e39 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f3a889 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 16. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 17. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 18. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 19. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:08:01.066475 [ 4888 ] {d6b943dc-998a-48af-86b7-0adc19aac1a4} DynamicQueryHandler: Code: 47. DB::Exception: Unknown expression identifier `x` in scope SELECT x FROM system.numbers LIMIT 1. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000013f69e39 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f3a889 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 16. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 17. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 18. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 19. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:08:01.594333 [ 6614 ] {d1102fac-ed2a-44eb-8d38-c908adcaa0dc} executeQuery: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:43920) (comment: 02899_use_default_format_on_http_exception.sh) (in query: INSERT INTO system.numbers Select * from numbers(10); ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/IStorage.cpp:162: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000015c3cd7a 5. /build/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&) @ 0x0000000016bd98a4 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000001484c2eb 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000001484dcd2 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001484f48c 9. /build/src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001485221d 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 12. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 13. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 14. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:08:01.702796 [ 6614 ] {d1102fac-ed2a-44eb-8d38-c908adcaa0dc} DynamicQueryHandler: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/IStorage.cpp:162: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000015c3cd7a 5. /build/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&) @ 0x0000000016bd98a4 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000001484c2eb 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000001484dcd2 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001484f48c 9. /build/src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001485221d 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 12. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 13. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 14. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:08:02.029856 [ 4888 ] {d8ebd9e3-6e88-40ac-947d-5d0148baeff0} executeQuery: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:43930) (comment: 02899_use_default_format_on_http_exception.sh) (in query: INSERT INTO system.numbers Select * from numbers(10); ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/IStorage.cpp:162: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000015c3cd7a 5. /build/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&) @ 0x0000000016bd98a4 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000001484c2eb 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000001484dcd2 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001484f48c 9. /build/src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001485221d 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 12. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 13. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 14. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:08:02.039839 [ 4888 ] {d8ebd9e3-6e88-40ac-947d-5d0148baeff0} DynamicQueryHandler: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/IStorage.cpp:162: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000015c3cd7a 5. /build/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&) @ 0x0000000016bd98a4 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000001484c2eb 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000001484dcd2 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001484f48c 9. /build/src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001485221d 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 12. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 13. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 14. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:08:02.390321 [ 6168 ] {743d3c46-7516-4dc3-8c5d-58776f758c17} executeQuery: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:43932) (comment: 02899_use_default_format_on_http_exception.sh) (in query: INSERT INTO system.numbers Select * from numbers(10); ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/IStorage.cpp:162: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000015c3cd7a 5. /build/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&) @ 0x0000000016bd98a4 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000001484c2eb 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000001484dcd2 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001484f48c 9. /build/src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001485221d 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 12. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 13. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 14. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:08:02.456819 [ 6168 ] {743d3c46-7516-4dc3-8c5d-58776f758c17} executeQuery: Code: 73. DB::Exception: Unknown format BADFORMAT. (UNKNOWN_FORMAT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Formats/FormatFactory.cpp:75: DB::FormatFactory::getCreators(String const&) const @ 0x000000001684494d 5. /build/src/Formats/FormatFactory.cpp:590: DB::FormatFactory::getOutputFormat(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x0000000016849965 6. /build/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 @ 0x0000000014bae103 7. /build/src/Interpreters/executeQuery.cpp:1767: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014bac18e 8. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 9. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 10. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:08:02.473425 [ 6168 ] {743d3c46-7516-4dc3-8c5d-58776f758c17} DynamicQueryHandler: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/IStorage.cpp:162: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000015c3cd7a 5. /build/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&) @ 0x0000000016bd98a4 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000001484c2eb 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000001484dcd2 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001484f48c 9. /build/src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001485221d 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 12. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 13. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 14. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:08:02.728447 [ 4888 ] {af2247bd-7929-405a-8c16-74546bc53fbc} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `x` in scope SELECT x FROM system.numbers LIMIT 1. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:43936) (comment: 02899_use_default_format_on_http_exception.sh) (in query: SELECT x FROM system.numbers LIMIT 1; ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000013f69e39 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f3a889 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 16. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 17. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 18. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 19. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:08:02.741327 [ 4888 ] {af2247bd-7929-405a-8c16-74546bc53fbc} DynamicQueryHandler: Code: 47. DB::Exception: Unknown expression identifier `x` in scope SELECT x FROM system.numbers LIMIT 1. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000013f69e39 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f3a889 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 16. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 17. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 18. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 19. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:08:03.067483 [ 6168 ] {c039187e-1ca7-47c9-911a-da3d38514228} executeQuery: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:43950) (comment: 02899_use_default_format_on_http_exception.sh) (in query: INSERT INTO system.numbers Select * from numbers(10); ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/IStorage.cpp:162: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000015c3cd7a 5. /build/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&) @ 0x0000000016bd98a4 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000001484c2eb 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000001484dcd2 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001484f48c 9. /build/src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001485221d 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 12. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 13. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 14. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:08:03.084724 [ 6168 ] {c039187e-1ca7-47c9-911a-da3d38514228} DynamicQueryHandler: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/IStorage.cpp:162: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000015c3cd7a 5. /build/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&) @ 0x0000000016bd98a4 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000001484c2eb 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000001484dcd2 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001484f48c 9. /build/src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001485221d 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 12. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 13. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 14. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:08:03.263895 [ 6614 ] {30e9eada-4fc7-4b5b-920d-e260149496a7} 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 0.0.0.0:0) (comment: 03247_materialized_view_select_intersect.sql) (in query: /* ddl_entry=query-0000000002 */ CREATE MATERIALIZED VIEW test_lgia9ab9.v0 UUID '24ead032-abb6-49ef-a3a0-2c806e9efb9c' TO INNER UUID 'e9f773e1-feab-4019-a24d-4c473d906649' (`1` UInt8) ENGINE = MergeTree AS SELECT 1 INTERSECT ALL SELECT 1), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Storages/SelectQueryDescription.cpp:82: DB::(anonymous namespace)::checkAllowedQueries(DB::ASTSelectWithUnionQuery const&) @ 0x0000000015c72e0a 5. /build/src/Storages/SelectQueryDescription.cpp:113: DB::SelectQueryDescription::getSelectQueryFromASTForMatView(std::shared_ptr const&, bool, std::shared_ptr) @ 0x0000000015c72976 6. /build/src/Storages/StorageMaterializedView.cpp:143: DB::StorageMaterializedView::StorageMaterializedView(DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel, String const&) @ 0x0000000015d3a707 7. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&, 0>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&) @ 0x0000000015d45a6b 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:se190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000015d4474b 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ca1a22 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001481ee32 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 14. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 15. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 16. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 17. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 18. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 19. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 20. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 21. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:08:03.334988 [ 16756 ] {a705661d-f55f-4e3e-b543-00d99a71d3a3} executeQuery: Code: 43. DB::Exception: Illegal type UInt8 of argument of function position: In scope SELECT if(CAST(position(65, '\n'), 'UInt8'), splitByChar(',', substring(65, 1, position(65, '\n') - 1)), splitByChar(',', substring(65, 1, length(65)))). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54396) (comment: 02366_kql_func_string.sql) (query 274, line 309) (in query: print parse_csv(65);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/FunctionsStringSearch.h:146: DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000e48d266 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4e8a9 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 28. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 29. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 2025.07.13 02:08:03.360126 [ 6614 ] {30e9eada-4fc7-4b5b-920d-e260149496a7} 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]:53744) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Storages/SelectQueryDescription.cpp:82: DB::(anonymous namespace)::checkAllowedQueries(DB::ASTSelectWithUnionQuery const&) @ 0x0000000015c72e0a 5. /build/src/Storages/SelectQueryDescription.cpp:113: DB::SelectQueryDescription::getSelectQueryFromASTForMatView(std::shared_ptr const&, bool, std::shared_ptr) @ 0x0000000015c72976 6. /build/src/Storages/StorageMaterializedView.cpp:143: DB::StorageMaterializedView::StorageMaterializedView(DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel, String const&) @ 0x0000000015d3a707 7. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&, 0>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&) @ 0x0000000015d45a6b 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:se190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000015d4474b 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ca1a22 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001481ee32 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 14. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 15. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 16. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 17. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 18. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 19. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 20. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 21. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:08:03.368479 [ 16756 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type UInt8 of argument of function position: In scope SELECT if(CAST(position(65, '\n'), 'UInt8'), splitByChar(',', substring(65, 1, position(65, '\n') - 1)), splitByChar(',', substring(65, 1, length(65)))). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/FunctionsStringSearch.h:146: DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000e48d266 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4e8a9 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 28. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 29. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 2025.07.13 02:08:03.373610 [ 6614 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Storages/SelectQueryDescription.cpp:82: DB::(anonymous namespace)::checkAllowedQueries(DB::ASTSelectWithUnionQuery const&) @ 0x0000000015c72e0a 5. /build/src/Storages/SelectQueryDescription.cpp:113: DB::SelectQueryDescription::getSelectQueryFromASTForMatView(std::shared_ptr const&, bool, std::shared_ptr) @ 0x0000000015c72976 6. /build/src/Storages/StorageMaterializedView.cpp:143: DB::StorageMaterializedView::StorageMaterializedView(DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel, String const&) @ 0x0000000015d3a707 7. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&, 0>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&) @ 0x0000000015d45a6b 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:se190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000015d4474b 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ca1a22 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001481ee32 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 14. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 15. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 16. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 17. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 18. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 19. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 20. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 21. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:08:03.406528 [ 4888 ] {f94fa305-438d-47a5-9742-69670b585bcc} executeQuery: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:43954) (comment: 02899_use_default_format_on_http_exception.sh) (in query: INSERT INTO system.numbers Select * from numbers(10); ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/IStorage.cpp:162: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000015c3cd7a 5. /build/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&) @ 0x0000000016bd98a4 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000001484c2eb 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000001484dcd2 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001484f48c 9. /build/src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001485221d 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 12. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 13. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 14. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:08:03.430370 [ 4888 ] {f94fa305-438d-47a5-9742-69670b585bcc} DynamicQueryHandler: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/IStorage.cpp:162: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000015c3cd7a 5. /build/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&) @ 0x0000000016bd98a4 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000001484c2eb 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000001484dcd2 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001484f48c 9. /build/src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001485221d 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 12. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 13. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 14. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:08:03.772677 [ 6614 ] {7a6b7df4-f042-4a84-8d3e-efc161dcb56e} executeQuery: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:43964) (comment: 02899_use_default_format_on_http_exception.sh) (in query: INSERT INTO system.numbers Select * from numbers(10); ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/IStorage.cpp:162: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000015c3cd7a 5. /build/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&) @ 0x0000000016bd98a4 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000001484c2eb 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000001484dcd2 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001484f48c 9. /build/src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001485221d 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 12. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 13. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 14. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:08:03.778166 [ 6614 ] {7a6b7df4-f042-4a84-8d3e-efc161dcb56e} executeQuery: Code: 73. DB::Exception: Unknown format BADFORMAT. (UNKNOWN_FORMAT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Formats/FormatFactory.cpp:75: DB::FormatFactory::getCreators(String const&) const @ 0x000000001684494d 5. /build/src/Formats/FormatFactory.cpp:590: DB::FormatFactory::getOutputFormat(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x0000000016849965 6. /build/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 @ 0x0000000014bae103 7. /build/src/Interpreters/executeQuery.cpp:1767: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014bac18e 8. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 9. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 10. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:08:03.887151 [ 6614 ] {7a6b7df4-f042-4a84-8d3e-efc161dcb56e} DynamicQueryHandler: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/IStorage.cpp:162: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000015c3cd7a 5. /build/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&) @ 0x0000000016bd98a4 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000001484c2eb 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000001484dcd2 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001484f48c 9. /build/src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001485221d 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 12. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 13. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 14. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:08:07.499273 [ 5998 ] {33755d8b-f748-47bb-98d0-cbb155aa6890} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 17.44 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]:53756) (comment: 02950_reading_array_tuple_subcolumns.sql) (query 4, line 11) (in query: INSERT INTO test SELECT number, tuple(number, arrayMap(x -> tuple(number + 1, number + 2), range(number % 10))) FROM numbers(100000);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x000000000fb2dd39 4. /build/src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2cb67 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2c5bf 6. /build/src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000fa9410c 7. /build/src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000000fa92864 8. /build/src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000000fb7acd2 9. /build/src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000000fb99f1e 10. /build/src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000000fb99608 11. /build/src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000000fc95b1c 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x0000000013ddc9c0 13. /build/src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x0000000013dd429d 14. /build/src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x00000000161478b9 15. /build/src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x00000000162f9dd2 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: void std::__function::__policy_invoker::__call_impl[abi:se190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000163069ca 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013b9f869 18. /build/src/DataTypes/Serializations/SerializationSparse.cpp:182: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000013c34d19 19. /build/src/DataTypes/Serializations/SerializationNamed.cpp:32: DB::SerializationNamed::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000013bf04b2 20. /build/src/DataTypes/Serializations/SerializationTuple.cpp:693: DB::SerializationTuple::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000013c457c9 21. /build/src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000013b9fb5d 22. /build/src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000016301a85 23. /build/src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000016301843 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x00000000162ee868 25. /build/src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000016217f1f 26. /build/src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000001643ef43 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x00000000163309fc 28. /build/src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001632dc9f 29. /build/src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x00000000165911f4 30. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016c130f3 31. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 2025.07.13 02:08:07.529120 [ 5998 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 17.44 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x000000000fb2dd39 4. /build/src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2cb67 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2c5bf 6. /build/src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000fa9410c 7. /build/src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000000fa92864 8. /build/src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000000fb7acd2 9. /build/src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000000fb99f1e 10. /build/src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000000fb99608 11. /build/src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000000fc95b1c 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x0000000013ddc9c0 13. /build/src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x0000000013dd429d 14. /build/src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x00000000161478b9 15. /build/src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x00000000162f9dd2 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: void std::__function::__policy_invoker::__call_impl[abi:se190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000163069ca 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013b9f869 18. /build/src/DataTypes/Serializations/SerializationSparse.cpp:182: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000013c34d19 19. /build/src/DataTypes/Serializations/SerializationNamed.cpp:32: DB::SerializationNamed::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000013bf04b2 20. /build/src/DataTypes/Serializations/SerializationTuple.cpp:693: DB::SerializationTuple::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000013c457c9 21. /build/src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000013b9fb5d 22. /build/src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000016301a85 23. /build/src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000016301843 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x00000000162ee868 25. /build/src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000016217f1f 26. /build/src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000001643ef43 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x00000000163309fc 28. /build/src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001632dc9f 29. /build/src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x00000000165911f4 30. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016c130f3 31. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x00000000168cf907 5. /build/src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000001680710e 6. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 2025.07.13 02:08:09.320593 [ 5998 ] {d007e3cb-876b-4027-8d00-d75e115097fb} executeQuery: Code: 53. DB::Exception: Return type of lambda function must be the same as the accumulator type, inferred return type of lambda: Nullable(Int64), inferred type of accumulator: Int64: In scope SELECT arrayFold((acc, x) -> (acc + (x * 2)), CAST('[1, 2, 3, 4]', 'Array(Nullable(Int64))'), toInt64(3)). (TYPE_MISMATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53784) (comment: 02990_arrayFold_nullable_lc.sql) (query 5, line 7) (in query: SELECT arrayFold((acc, x) -> (acc + (x * 2)), [1, 2, 3, 4]::Array(Nullable(Int64)), toInt64(3));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/array/arrayFold.cpp:76: DB::FunctionArrayFold::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f4545a1 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 6. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80f9b 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:08:09.329979 [ 5998 ] {} TCPHandler: Code: 53. DB::Exception: Return type of lambda function must be the same as the accumulator type, inferred return type of lambda: Nullable(Int64), inferred type of accumulator: Int64: In scope SELECT arrayFold((acc, x) -> (acc + (x * 2)), CAST('[1, 2, 3, 4]', 'Array(Nullable(Int64))'), toInt64(3)). (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/array/arrayFold.cpp:76: DB::FunctionArrayFold::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f4545a1 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 6. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80f9b 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:08:09.753524 [ 4930 ] {5b7b3e41-6804-4660-a7b3-a6932c3d1fdc} 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 0.0.0.0:0) (comment: 00705_drop_create_merge_tree.sh) (in query: /* ddl_entry=query-0000000142 */ CREATE TABLE IF NOT EXISTS test_11.`table` UUID 'ab3da2df-5f16-4cff-8373-ccd898a61c29' (`x` UInt8) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 27256, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 11, min_bytes_for_full_part_storage = 440664447, compact_parts_max_bytes_to_buffer = 54314631, compact_parts_max_granules_to_buffer = 147, compact_parts_merge_max_bytes_to_prefetch_part = 31839753, merge_max_block_size = 8882, old_parts_lifetime = 314., 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 = 26350710, 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 = 71029, primary_key_compress_block_size = 87806, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000118cbf6e 8. /build/src/Storages/MergeTree/MergeTreeData.cpp:1922: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x0000000016238b3d 9. /build/src/Storages/StorageMergeTree.cpp:161: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000016556df5 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000165568d0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000165531fd 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ca1a22 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001481ee32 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 17. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 18. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 19. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 20. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 21. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 22. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 23. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 24. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:08:09.817560 [ 4930 ] {5b7b3e41-6804-4660-a7b3-a6932c3d1fdc} 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]:34214) (comment: 00705_drop_create_merge_tree.sh) (query 49, line 49) (in query: CREATE TABLE IF NOT EXISTS `table` (`x` UInt8) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 27256, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 11, min_bytes_for_full_part_storage = 440664447, compact_parts_max_bytes_to_buffer = 54314631, compact_parts_max_granules_to_buffer = 147, compact_parts_merge_max_bytes_to_prefetch_part = 31839753, merge_max_block_size = 8882, old_parts_lifetime = 314., 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 = 26350710, 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 = 71029, primary_key_compress_block_size = 87806, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000118cbf6e 8. /build/src/Storages/MergeTree/MergeTreeData.cpp:1922: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x0000000016238b3d 9. /build/src/Storages/StorageMergeTree.cpp:161: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000016556df5 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000165568d0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000165531fd 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ca1a22 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001481ee32 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 17. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 18. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 19. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 20. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 21. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 22. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 23. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 24. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:08:09.857462 [ 4930 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000118cbf6e 8. /build/src/Storages/MergeTree/MergeTreeData.cpp:1922: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x0000000016238b3d 9. /build/src/Storages/StorageMergeTree.cpp:161: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000016556df5 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000165568d0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000165531fd 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ca1a22 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001481ee32 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 17. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 18. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 19. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 20. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 21. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 22. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 23. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 24. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:08:11.187789 [ 16758 ] {9becc732-5cc6-40f3-b0bc-30e36e731afa} 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]:53608) (comment: 01526_alter_add_and_modify_order_zookeeper.sql) (query 3, line 7) (in query: CREATE TABLE table_for_alter ( `d` Date, `a` String, `b` UInt8, `x` String, `y` Int8, `version` UInt64, `sign` Int8 DEFAULT 1 ) ENGINE = ReplicatedVersionedCollapsingMergeTree('/clickhouse/tables/{database}/01526_alter_add/t1', '1', sign, version) PARTITION BY y ORDER BY d SETTINGS index_granularity = 8192;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000013cc1696 5. /build/src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013cc32f5 6. /build/src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc384b 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:08:11.300117 [ 16758 ] {} TCPHandler: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000013cc1696 5. /build/src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013cc32f5 6. /build/src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc384b 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:08:11.312482 [ 5998 ] {ba180985-7231-4509-b764-68385fbb28f1} executeQuery: Code: 53. DB::Exception: Return type of lambda function must be the same as the accumulator type, inferred return type of lambda: Nullable(Int64), inferred type of accumulator: Int64: In scope SELECT arrayFold((acc, x) -> toNullable(acc + (x * 2)), [1, 2, 3, 4], toInt64(3)). (TYPE_MISMATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53784) (comment: 02990_arrayFold_nullable_lc.sql) (query 14, line 19) (in query: SELECT arrayFold((acc, x) -> toNullable(acc + (x * 2)), [1, 2, 3, 4], toInt64(3));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/array/arrayFold.cpp:76: DB::FunctionArrayFold::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f4545a1 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 6. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80f9b 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:08:11.334319 [ 5998 ] {} TCPHandler: Code: 53. DB::Exception: Return type of lambda function must be the same as the accumulator type, inferred return type of lambda: Nullable(Int64), inferred type of accumulator: Int64: In scope SELECT arrayFold((acc, x) -> toNullable(acc + (x * 2)), [1, 2, 3, 4], toInt64(3)). (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/array/arrayFold.cpp:76: DB::FunctionArrayFold::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f4545a1 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 6. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80f9b 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:08:11.727946 [ 5998 ] {bb0c060d-1626-44d9-95c0-9548acccffb1} executeQuery: Code: 53. DB::Exception: Return type of lambda function must be the same as the accumulator type, inferred return type of lambda: Int64, inferred type of accumulator: LowCardinality(Int64): In scope SELECT arrayFold((acc, x) -> (acc + (x * 2)), [1, 2, 3, 4], toLowCardinality(toInt64(3))). (TYPE_MISMATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53784) (comment: 02990_arrayFold_nullable_lc.sql) (query 16, line 22) (in query: SELECT arrayFold((acc, x) -> (acc + (x * 2)), [1, 2, 3, 4], toLowCardinality(toInt64(3)));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/array/arrayFold.cpp:76: DB::FunctionArrayFold::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f4545a1 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 6. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80f9b 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:08:11.733873 [ 5998 ] {} TCPHandler: Code: 53. DB::Exception: Return type of lambda function must be the same as the accumulator type, inferred return type of lambda: Int64, inferred type of accumulator: LowCardinality(Int64): In scope SELECT arrayFold((acc, x) -> (acc + (x * 2)), [1, 2, 3, 4], toLowCardinality(toInt64(3))). (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/array/arrayFold.cpp:76: DB::FunctionArrayFold::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f4545a1 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 6. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80f9b 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:08:12.044221 [ 5998 ] {607de2c1-6f98-4dc5-8807-960ff9ff1668} executeQuery: Code: 53. DB::Exception: Return type of lambda function must be the same as the accumulator type, inferred return type of lambda: Int64, inferred type of accumulator: LowCardinality(Int64): In scope SELECT arrayFold((acc, x) -> (acc + (x * 2)), CAST('[1, 2, 3, 4]', 'Array(LowCardinality(Int64))'), toInt64(toLowCardinality(3))). (TYPE_MISMATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53784) (comment: 02990_arrayFold_nullable_lc.sql) (query 18, line 24) (in query: SELECT arrayFold((acc, x) -> (acc + (x * 2)), [1, 2, 3, 4]::Array(LowCardinality(Int64)), toInt64(toLowCardinality(3)));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/array/arrayFold.cpp:76: DB::FunctionArrayFold::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f4545a1 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 6. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80f9b 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:08:12.052428 [ 5998 ] {} TCPHandler: Code: 53. DB::Exception: Return type of lambda function must be the same as the accumulator type, inferred return type of lambda: Int64, inferred type of accumulator: LowCardinality(Int64): In scope SELECT arrayFold((acc, x) -> (acc + (x * 2)), CAST('[1, 2, 3, 4]', 'Array(LowCardinality(Int64))'), toInt64(toLowCardinality(3))). (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/array/arrayFold.cpp:76: DB::FunctionArrayFold::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f4545a1 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 6. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80f9b 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:08:12.498629 [ 5998 ] {e6d18da1-1c5b-47eb-b49c-c94cc29bd563} executeQuery: Code: 53. DB::Exception: Return type of lambda function must be the same as the accumulator type, inferred return type of lambda: Nullable(Int64), inferred type of accumulator: LowCardinality(Int64): In scope SELECT arrayFold((acc, x) -> (acc + (x * 2)), CAST('[1, 2, 3, 4]', 'Array(Nullable(Int64))'), toInt64(toLowCardinality(3))). (TYPE_MISMATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53784) (comment: 02990_arrayFold_nullable_lc.sql) (query 20, line 27) (in query: SELECT arrayFold((acc, x) -> acc + (x * 2), [1, 2, 3, 4]::Array(Nullable(Int64)), toInt64(toLowCardinality(3)));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/array/arrayFold.cpp:76: DB::FunctionArrayFold::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f4545a1 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 6. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80f9b 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:08:12.518531 [ 5998 ] {} TCPHandler: Code: 53. DB::Exception: Return type of lambda function must be the same as the accumulator type, inferred return type of lambda: Nullable(Int64), inferred type of accumulator: LowCardinality(Int64): In scope SELECT arrayFold((acc, x) -> (acc + (x * 2)), CAST('[1, 2, 3, 4]', 'Array(Nullable(Int64))'), toInt64(toLowCardinality(3))). (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/array/arrayFold.cpp:76: DB::FunctionArrayFold::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f4545a1 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 6. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80f9b 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:08:12.798941 [ 5998 ] {0561b315-e41e-4478-aea5-a942205de29c} executeQuery: Code: 53. DB::Exception: Return type of lambda function must be the same as the accumulator type, inferred return type of lambda: LowCardinality(Nullable(Int64)), inferred type of accumulator: LowCardinality(Int64): In scope SELECT arrayFold((acc, x) -> toLowCardinality(acc + (x * 2)), CAST('[1, 2, 3, 4]', 'Array(Nullable(Int64))'), toInt64(toLowCardinality(3))). (TYPE_MISMATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53784) (comment: 02990_arrayFold_nullable_lc.sql) (query 21, line 28) (in query: SELECT arrayFold((acc, x) -> toLowCardinality(acc + (x * 2)), [1, 2, 3, 4]::Array(Nullable(Int64)), toInt64(toLowCardinality(3)));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/array/arrayFold.cpp:76: DB::FunctionArrayFold::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f4545a1 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 6. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80f9b 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:08:12.807702 [ 5998 ] {} TCPHandler: Code: 53. DB::Exception: Return type of lambda function must be the same as the accumulator type, inferred return type of lambda: LowCardinality(Nullable(Int64)), inferred type of accumulator: LowCardinality(Int64): In scope SELECT arrayFold((acc, x) -> toLowCardinality(acc + (x * 2)), CAST('[1, 2, 3, 4]', 'Array(Nullable(Int64))'), toInt64(toLowCardinality(3))). (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/array/arrayFold.cpp:76: DB::FunctionArrayFold::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f4545a1 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 6. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80f9b 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:08:12.934512 [ 5998 ] {a89d0311-cc59-40d2-ac4c-f35c5f93ea81} executeQuery: Code: 53. DB::Exception: Return type of lambda function must be the same as the accumulator type, inferred return type of lambda: LowCardinality(Nullable(Int64)), inferred type of accumulator: Nullable(Int64): In scope SELECT arrayFold((acc, x) -> toLowCardinality(acc + (x * 2)), CAST('[1, 2, 3, 4]', 'Array(Nullable(Int64))'), toInt64(toNullable(3))). (TYPE_MISMATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53784) (comment: 02990_arrayFold_nullable_lc.sql) (query 22, line 29) (in query: SELECT arrayFold((acc, x) -> toLowCardinality(acc + (x * 2)), [1, 2, 3, 4]::Array(Nullable(Int64)), toInt64(toNullable(3)));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/array/arrayFold.cpp:76: DB::FunctionArrayFold::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f4545a1 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 6. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80f9b 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:08:12.959902 [ 5998 ] {} TCPHandler: Code: 53. DB::Exception: Return type of lambda function must be the same as the accumulator type, inferred return type of lambda: LowCardinality(Nullable(Int64)), inferred type of accumulator: Nullable(Int64): In scope SELECT arrayFold((acc, x) -> toLowCardinality(acc + (x * 2)), CAST('[1, 2, 3, 4]', 'Array(Nullable(Int64))'), toInt64(toNullable(3))). (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/array/arrayFold.cpp:76: DB::FunctionArrayFold::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f4545a1 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 6. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80f9b 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:08:13.224067 [ 5998 ] {d2fe2c5c-78e4-4dc3-bb16-21161600e049} executeQuery: Code: 53. DB::Exception: Return type of lambda function must be the same as the accumulator type, inferred return type of lambda: Nullable(Int64), inferred type of accumulator: LowCardinality(Nullable(Int64)): In scope SELECT arrayFold((acc, x) -> (acc + (x * 2)), [1, 2, 3, 4], CAST(NULL, 'LowCardinality(Nullable(Int64))')). (TYPE_MISMATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53784) (comment: 02990_arrayFold_nullable_lc.sql) (query 24, line 32) (in query: -- It's debatable which one of the following 2 queries should work, but considering the return type must match the -- accumulator type it makes sense to be the second one SELECT arrayFold((acc, x) -> (acc + (x * 2)), [1, 2, 3, 4], NULL::LowCardinality(Nullable(Int64)));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/array/arrayFold.cpp:76: DB::FunctionArrayFold::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f4545a1 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 6. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80f9b 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:08:13.230482 [ 5998 ] {} TCPHandler: Code: 53. DB::Exception: Return type of lambda function must be the same as the accumulator type, inferred return type of lambda: Nullable(Int64), inferred type of accumulator: LowCardinality(Nullable(Int64)): In scope SELECT arrayFold((acc, x) -> (acc + (x * 2)), [1, 2, 3, 4], CAST(NULL, 'LowCardinality(Nullable(Int64))')). (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/array/arrayFold.cpp:76: DB::FunctionArrayFold::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f4545a1 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 6. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80f9b 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:08:19.497238 [ 6168 ] {52fb8919-c8ab-4915-997a-c821b36e79a6} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53752) (comment: 02099_hashed_array_dictionary_complex_key.gen.sql) (query 22, line 48) (in query: DROP DICTIONARY hashed_array_dictionary_complex_key_simple_attributes;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833ede 5. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 7. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 10. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:08:19.517732 [ 6168 ] {} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833ede 5. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 7. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 10. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:08:21.595782 [ 5987 ] {64fe9363-5603-424d-bb1f-e7589b12b7d5} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=851, jobs=797). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:37556) (comment: 00871_t64_codec_signed.sql) (query 56, line 74) (in query: SELECT `__table1`.`i8` AS `i8`, `__table1`.`t_i8` AS `t_i8`, `__table1`.`i16` AS `i16`, `__table1`.`t_i16` AS `t_i16`, `__table1`.`i32` AS `i32`, `__table1`.`t_i32` AS `t_i32`, `__table1`.`i64` AS `i64`, `__table1`.`t_i64` AS `t_i64` FROM `test_15`.`t64` AS `__table1` WHERE `__table1`.`i64` != `__table1`.`t_i64`), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbdd1d3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd751c 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 9. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 10. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:08:21.645473 [ 5987 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=851, jobs=797). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbdd1d3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd751c 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 9. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 10. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:08:21.694795 [ 5018 ] {fe5b1564-387a-4c72-9b68-48862168a142} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.5:9000. DB::Exception: Cannot schedule a task: fault injected (threads=851, jobs=797). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbdd1d3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd751c 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 9. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 10. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37870) (comment: 00871_t64_codec_signed.sql) (query 56, line 74) (in query: SELECT * FROM t64 WHERE i64 != t_i64;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fb80677 3. /build/src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x00000000166f5247 4. /build/src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000166fc432 5. /build/src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x0000000016737609 6. /build/src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000013af731e 7. /build/src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013af6952 8. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013af679a 9. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013af64e1 2025.07.13 02:08:21.755358 [ 5018 ] {} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.5:9000. DB::Exception: Cannot schedule a task: fault injected (threads=851, jobs=797). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbdd1d3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd751c 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 9. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 10. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 : While executing Remote. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fb80677 3. /build/src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x00000000166f5247 4. /build/src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000166fc432 5. /build/src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x0000000016737609 6. /build/src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000013af731e 7. /build/src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013af6952 8. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013af679a 9. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013af64e1 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:08:22.675623 [ 16756 ] {4214395f-7f2b-43d5-8a78-61bfaf686daa} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDhhmmssToDateTime'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT YYYYMMDDhhmmssToDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46868) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (query 4, line 7) (in query: SELECT YYYYMMDDhhmmssToDateTime();), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000012c9192b 4. /build/src/Functions/FunctionHelpers.cpp:184: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c90171 5. /build/src/Functions/makeDate.cpp:576: DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ce9736a 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:08:22.710226 [ 16756 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDhhmmssToDateTime'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT YYYYMMDDhhmmssToDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000012c9192b 4. /build/src/Functions/FunctionHelpers.cpp:184: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c90171 5. /build/src/Functions/makeDate.cpp:576: DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ce9736a 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:08:22.920677 [ 16756 ] {c56ba03d-6038-46ca-bb57-21317e735c83} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime'. Expected: Number, got: Date: In scope SELECT YYYYMMDDhhmmssToDateTime(toDate('2023-09-11')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46868) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (query 5, line 8) (in query: SELECT YYYYMMDDhhmmssToDateTime(toDate('2023-09-11'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/makeDate.cpp:576: DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ce9736a 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:08:22.939742 [ 16756 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime'. Expected: Number, got: Date: In scope SELECT YYYYMMDDhhmmssToDateTime(toDate('2023-09-11')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/makeDate.cpp:576: DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ce9736a 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:08:23.088894 [ 16756 ] {f8c46748-2ee5-430d-9a1c-07e974c8d385} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime'. Expected: Number, got: Date32: In scope SELECT YYYYMMDDhhmmssToDateTime(toDate32('2023-09-11')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46868) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (query 6, line 9) (in query: SELECT YYYYMMDDhhmmssToDateTime(toDate32('2023-09-11'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/makeDate.cpp:576: DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ce9736a 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:08:23.113379 [ 16756 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime'. Expected: Number, got: Date32: In scope SELECT YYYYMMDDhhmmssToDateTime(toDate32('2023-09-11')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/makeDate.cpp:576: DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ce9736a 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:08:23.239809 [ 16756 ] {ff592403-31ef-4050-8916-7c00b9134b1b} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime'. Expected: Number, got: DateTime: In scope SELECT YYYYMMDDhhmmssToDateTime(toDateTime('2023-09-11 12:18:00')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46868) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (query 7, line 10) (in query: SELECT YYYYMMDDhhmmssToDateTime(toDateTime('2023-09-11 12:18:00'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/makeDate.cpp:576: DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ce9736a 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:08:23.247526 [ 16756 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime'. Expected: Number, got: DateTime: In scope SELECT YYYYMMDDhhmmssToDateTime(toDateTime('2023-09-11 12:18:00')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/makeDate.cpp:576: DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ce9736a 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:08:23.402072 [ 16756 ] {2bc62866-77d1-494a-8439-d8cfb05f54d4} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime'. Expected: Number, got: DateTime64(3): In scope SELECT YYYYMMDDhhmmssToDateTime(toDateTime64('2023-09-11 12:18:00', 3)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46868) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (query 8, line 11) (in query: SELECT YYYYMMDDhhmmssToDateTime(toDateTime64('2023-09-11 12:18:00', 3));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/makeDate.cpp:576: DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ce9736a 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:08:23.410559 [ 16756 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime'. Expected: Number, got: DateTime64(3): In scope SELECT YYYYMMDDhhmmssToDateTime(toDateTime64('2023-09-11 12:18:00', 3)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/makeDate.cpp:576: DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ce9736a 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:08:23.554133 [ 16756 ] {365dba9c-b58a-44f3-94ff-982e44eaa8b9} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime'. Expected: Number, got: String: In scope SELECT YYYYMMDDhhmmssToDateTime('2023-09-11'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46868) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (query 9, line 12) (in query: SELECT YYYYMMDDhhmmssToDateTime('2023-09-11');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/makeDate.cpp:576: DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ce9736a 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:08:23.564917 [ 16756 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime'. Expected: Number, got: String: In scope SELECT YYYYMMDDhhmmssToDateTime('2023-09-11'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/makeDate.cpp:576: DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ce9736a 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:08:23.658052 [ 6168 ] {274f8c02-248f-4eeb-a155-7f1a3891cc26} 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]:51094) (comment: 00361_shared_array_offsets_and_squash_blocks.sql) (in query: DROP DATABASE IF EXISTS test_4r3hip1k SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:08:23.681314 [ 6168 ] {274f8c02-248f-4eeb-a155-7f1a3891cc26} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:08:23.864166 [ 16756 ] {7c66398c-acb2-407d-ad17-a0b88f236fea} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'timezone' to function 'YYYYMMDDhhmmssToDateTime'. Expected: const String, got: UInt8: In scope SELECT YYYYMMDDhhmmssToDateTime(20230911134254, 3). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46868) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (query 10, line 13) (in query: SELECT YYYYMMDDhhmmssToDateTime(20230911134254, 3);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/makeDate.cpp:576: DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ce9736a 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:08:23.875983 [ 16756 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'timezone' to function 'YYYYMMDDhhmmssToDateTime'. Expected: const String, got: UInt8: In scope SELECT YYYYMMDDhhmmssToDateTime(20230911134254, 3). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/makeDate.cpp:576: DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ce9736a 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:08:24.139077 [ 16756 ] {f017c9e3-5b40-420b-b080-0045ef7ef4f1} executeQuery: Code: 36. DB::Exception: Cannot load time zone invalid tz: In scope SELECT YYYYMMDDhhmmssToDateTime(20230911134254, 'invalid tz'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46868) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (query 11, line 14) (in query: SELECT YYYYMMDDhhmmssToDateTime(20230911134254, 'invalid tz');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x000000000faae8c8 5. /build/src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x000000000faaaf5e 6. /build/src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x0000000013b01446 7. /build/src/DataTypes/DataTypeDateTime.cpp:11: DB::DataTypeDateTime::DataTypeDateTime(String const&) @ 0x0000000013b011e9 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], String&, 0>(std::allocator const&, String&) @ 0x000000000b12d63c 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ce973eb 10. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 11. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 12. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:08:24.195192 [ 16756 ] {} TCPHandler: Code: 36. DB::Exception: Cannot load time zone invalid tz: In scope SELECT YYYYMMDDhhmmssToDateTime(20230911134254, 'invalid tz'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x000000000faae8c8 5. /build/src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x000000000faaaf5e 6. /build/src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x0000000013b01446 7. /build/src/DataTypes/DataTypeDateTime.cpp:11: DB::DataTypeDateTime::DataTypeDateTime(String const&) @ 0x0000000013b011e9 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], String&, 0>(std::allocator const&, String&) @ 0x000000000b12d63c 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ce973eb 10. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 11. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 12. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:08:24.378202 [ 16756 ] {66679abf-eeac-42d2-8576-369f462b8b8b} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDhhmmssToDateTime'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT YYYYMMDDhhmmssToDateTime(20230911134254, 'Europe/Berlin', 'bad'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46868) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (query 12, line 15) (in query: SELECT YYYYMMDDhhmmssToDateTime(20230911134254, 'Europe/Berlin', 'bad');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000012c9192b 4. /build/src/Functions/FunctionHelpers.cpp:184: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c90171 5. /build/src/Functions/makeDate.cpp:576: DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ce9736a 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:08:24.408166 [ 16756 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDhhmmssToDateTime'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT YYYYMMDDhhmmssToDateTime(20230911134254, 'Europe/Berlin', 'bad'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000012c9192b 4. /build/src/Functions/FunctionHelpers.cpp:184: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c90171 5. /build/src/Functions/makeDate.cpp:576: DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ce9736a 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:08:24.968152 [ 6611 ] {a223b02d-18bc-4e0d-8c33-4a0f70a81243} 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]:53688) (comment: 01821_join_table_race_long.sh) (query 81, line 81) (in query: SELECT count() FROM join_table_race FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda7a6 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 9. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:08:25.005624 [ 6611 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda7a6 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 9. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:08:28.988123 [ 16756 ] {8473f5fa-9044-4d5c-a99a-2fde6a63eb32} executeQuery: Code: 36. DB::Exception: Argument for function YYYYMMDDhhmmssToDateTime must be finite: In scope SELECT YYYYMMDDhhmmssToDateTime(nan). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46868) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (query 31, line 37) (in query: SELECT YYYYMMDDhhmmssToDateTime(NaN);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/makeDate.cpp:604: DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ce970de 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:08:28.997201 [ 16756 ] {} TCPHandler: Code: 36. DB::Exception: Argument for function YYYYMMDDhhmmssToDateTime must be finite: In scope SELECT YYYYMMDDhhmmssToDateTime(nan). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/makeDate.cpp:604: DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ce970de 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:08:29.100958 [ 16756 ] {4f84490a-32e6-45ca-ac81-f478e2084788} executeQuery: Code: 36. DB::Exception: Argument for function YYYYMMDDhhmmssToDateTime must be finite: In scope SELECT YYYYMMDDhhmmssToDateTime(inf). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46868) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (query 32, line 38) (in query: SELECT YYYYMMDDhhmmssToDateTime(Inf);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/makeDate.cpp:604: DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ce970de 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:08:29.121347 [ 16756 ] {} TCPHandler: Code: 36. DB::Exception: Argument for function YYYYMMDDhhmmssToDateTime must be finite: In scope SELECT YYYYMMDDhhmmssToDateTime(inf). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/makeDate.cpp:604: DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ce970de 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:08:29.332093 [ 16756 ] {9215d3b5-8c7e-4589-9089-eb249b74277e} executeQuery: Code: 36. DB::Exception: Argument for function YYYYMMDDhhmmssToDateTime must be finite: In scope SELECT YYYYMMDDhhmmssToDateTime(-inf). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46868) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (query 33, line 39) (in query: SELECT YYYYMMDDhhmmssToDateTime(-Inf);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/makeDate.cpp:604: DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ce970de 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:08:29.372230 [ 16756 ] {} TCPHandler: Code: 36. DB::Exception: Argument for function YYYYMMDDhhmmssToDateTime must be finite: In scope SELECT YYYYMMDDhhmmssToDateTime(-inf). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/makeDate.cpp:604: DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ce970de 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:08:33.708813 [ 11007 ] {ece1fb27-d3b1-4025-b990-5b5f268af193} InterpreterCheckQuery: Check query for table test_1.tp_1 (6b9e53dc-051e-40e0-bf64-dfe6198da7fe) failed, path 0_5_5_0, reason: Code: 227. DB::Exception: Found unexpected projection directories: pp.proj. (UNEXPECTED_FILE_IN_DATA_PART) (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:08:35.409004 [ 6612 ] {39bb9f3a-54de-4c69-8ab6-a30371d91c81} executeQuery: Code: 159. DB::Exception: Timeout exceeded (180 s) while flushing system log 'DB::SystemLogQueue'. (TIMEOUT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60340) (comment: 03203_system_query_metric_log.sh) (query 1, line 1) (in query: SYSTEM FLUSH LOGS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Common/SystemLogBase.cpp:168: DB::SystemLogQueue::waitFlush(long, bool) @ 0x000000000fbee407 5. /build/src/Interpreters/SystemLog.cpp:437: DB::SystemLogs::flush(bool, std::vector> const&) @ 0x0000000014a1ea9f 6. /build/src/Interpreters/InterpreterSystemQuery.cpp:796: DB::InterpreterSystemQuery::execute() @ 0x0000000014bd5a4e 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:08:35.435457 [ 6612 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded (180 s) while flushing system log 'DB::SystemLogQueue'. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Common/SystemLogBase.cpp:168: DB::SystemLogQueue::waitFlush(long, bool) @ 0x000000000fbee407 5. /build/src/Interpreters/SystemLog.cpp:437: DB::SystemLogs::flush(bool, std::vector> const&) @ 0x0000000014a1ea9f 6. /build/src/Interpreters/InterpreterSystemQuery.cpp:796: DB::InterpreterSystemQuery::execute() @ 0x0000000014bd5a4e 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:08:36.070214 [ 16756 ] {b8470555-d66b-433d-9327-c559760b4b33} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDhhmmssToDateTime64'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT YYYYMMDDhhmmssToDateTime64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46868) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (query 58, line 69) (in query: SELECT YYYYMMDDhhmmssToDateTime64();), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000012c9192b 4. /build/src/Functions/FunctionHelpers.cpp:184: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c90171 5. /build/src/Functions/makeDate.cpp:656: DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ce98032 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:08:36.092062 [ 16756 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDhhmmssToDateTime64'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT YYYYMMDDhhmmssToDateTime64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000012c9192b 4. /build/src/Functions/FunctionHelpers.cpp:184: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c90171 5. /build/src/Functions/makeDate.cpp:656: DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ce98032 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:08:36.364694 [ 16756 ] {3581694c-6643-4510-8125-74db1ac98f04} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime64'. Expected: Number, got: Date: In scope SELECT YYYYMMDDhhmmssToDateTime64(toDate('2023-09-11')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46868) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (query 59, line 70) (in query: SELECT YYYYMMDDhhmmssToDateTime64(toDate('2023-09-11'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/makeDate.cpp:656: DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ce98032 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:08:36.379695 [ 16756 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime64'. Expected: Number, got: Date: In scope SELECT YYYYMMDDhhmmssToDateTime64(toDate('2023-09-11')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/makeDate.cpp:656: DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ce98032 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:08:36.446155 [ 16756 ] {70eb6c33-0d7d-4bdf-89da-f7094ac2681b} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime64'. Expected: Number, got: Date32: In scope SELECT YYYYMMDDhhmmssToDateTime64(toDate32('2023-09-11')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46868) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (query 60, line 71) (in query: SELECT YYYYMMDDhhmmssToDateTime64(toDate32('2023-09-11'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/makeDate.cpp:656: DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ce98032 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:08:36.455967 [ 16756 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime64'. Expected: Number, got: Date32: In scope SELECT YYYYMMDDhhmmssToDateTime64(toDate32('2023-09-11')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/makeDate.cpp:656: DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ce98032 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:08:36.599736 [ 16756 ] {2569e4c5-f3aa-4c2c-947c-351e9bcb700b} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime64'. Expected: Number, got: DateTime: In scope SELECT YYYYMMDDhhmmssToDateTime64(toDateTime('2023-09-11 12:18:00')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46868) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (query 61, line 72) (in query: SELECT YYYYMMDDhhmmssToDateTime64(toDateTime('2023-09-11 12:18:00'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/makeDate.cpp:656: DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ce98032 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:08:36.641829 [ 16756 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime64'. Expected: Number, got: DateTime: In scope SELECT YYYYMMDDhhmmssToDateTime64(toDateTime('2023-09-11 12:18:00')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/makeDate.cpp:656: DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ce98032 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:08:36.848424 [ 16756 ] {3cb1675a-d01d-432a-9f76-5683deca310b} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime64'. Expected: Number, got: DateTime64(3): In scope SELECT YYYYMMDDhhmmssToDateTime64(toDateTime64('2023-09-11 12:18:00', 3)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46868) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (query 62, line 73) (in query: SELECT YYYYMMDDhhmmssToDateTime64(toDateTime64('2023-09-11 12:18:00', 3));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/makeDate.cpp:656: DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ce98032 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:08:36.858461 [ 16756 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime64'. Expected: Number, got: DateTime64(3): In scope SELECT YYYYMMDDhhmmssToDateTime64(toDateTime64('2023-09-11 12:18:00', 3)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/makeDate.cpp:656: DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ce98032 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:08:36.974120 [ 16756 ] {b7eb08ff-7b3d-43c8-b3f0-0f774cdcd2d7} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime64'. Expected: Number, got: String: In scope SELECT YYYYMMDDhhmmssToDateTime64('2023-09-11'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46868) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (query 63, line 74) (in query: SELECT YYYYMMDDhhmmssToDateTime64('2023-09-11');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/makeDate.cpp:656: DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ce98032 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:08:36.980726 [ 16756 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime64'. Expected: Number, got: String: In scope SELECT YYYYMMDDhhmmssToDateTime64('2023-09-11'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/makeDate.cpp:656: DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ce98032 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:08:37.045882 [ 16756 ] {5f579f1b-ef85-4e21-9df1-83be6f9efbc3} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime64'. Expected: Number, got: String: In scope SELECT YYYYMMDDhhmmssToDateTime64('2023-09-11', 'invalid precision'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46868) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (query 64, line 75) (in query: SELECT YYYYMMDDhhmmssToDateTime64('2023-09-11', 'invalid precision');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/makeDate.cpp:656: DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ce98032 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:08:37.054515 [ 16756 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime64'. Expected: Number, got: String: In scope SELECT YYYYMMDDhhmmssToDateTime64('2023-09-11', 'invalid precision'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/makeDate.cpp:656: DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ce98032 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:08:37.263076 [ 16756 ] {eab6c761-ee8c-45c7-a303-8fd028c872a5} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'precision' to function 'YYYYMMDDhhmmssToDateTime64'. Expected: const String, got: UInt8: In scope SELECT YYYYMMDDhhmmssToDateTime64(20230911134254, 3, 3). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46868) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (query 65, line 76) (in query: SELECT YYYYMMDDhhmmssToDateTime64(20230911134254, 3, 3);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/makeDate.cpp:656: DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ce98032 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:08:37.295168 [ 16756 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'precision' to function 'YYYYMMDDhhmmssToDateTime64'. Expected: const String, got: UInt8: In scope SELECT YYYYMMDDhhmmssToDateTime64(20230911134254, 3, 3). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/makeDate.cpp:656: DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ce98032 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:08:37.712911 [ 16756 ] {4355cc64-34e0-41b4-8b2e-5279f22d34fb} executeQuery: Code: 36. DB::Exception: Cannot load time zone invalid tz: In scope SELECT YYYYMMDDhhmmssToDateTime64(20230911134254, 3, 'invalid tz'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46868) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (query 66, line 77) (in query: SELECT YYYYMMDDhhmmssToDateTime64(20230911134254, 3, 'invalid tz');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x000000000faae8c8 5. /build/src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x000000000faaaf5e 6. /build/src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x0000000013b01446 7. /build/src/DataTypes/DataTypeDateTime64.cpp:22: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x0000000013b01768 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], unsigned int&, String&, 0>(std::allocator const&, unsigned int&, String&) @ 0x000000000ce984c6 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ce980f8 10. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 11. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 12. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:08:37.727192 [ 16756 ] {} TCPHandler: Code: 36. DB::Exception: Cannot load time zone invalid tz: In scope SELECT YYYYMMDDhhmmssToDateTime64(20230911134254, 3, 'invalid tz'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x000000000faae8c8 5. /build/src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x000000000faaaf5e 6. /build/src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x0000000013b01446 7. /build/src/DataTypes/DataTypeDateTime64.cpp:22: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x0000000013b01768 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], unsigned int&, String&, 0>(std::allocator const&, unsigned int&, String&) @ 0x000000000ce984c6 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ce980f8 10. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 11. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 12. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:08:37.847474 [ 16756 ] {d5a70329-2715-4fc5-a07e-99afc0cd2b20} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDhhmmssToDateTime64'. Expected 1 mandatory argument and 2 optional arguments, got 4 arguments: In scope SELECT YYYYMMDDhhmmssToDateTime64(20230911134254, 3, 'Europe/Berlin', 'no more args'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46868) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (query 67, line 78) (in query: SELECT YYYYMMDDhhmmssToDateTime64(20230911134254, 3, 'Europe/Berlin', 'no more args');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000012c9192b 4. /build/src/Functions/FunctionHelpers.cpp:184: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c90171 5. /build/src/Functions/makeDate.cpp:656: DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ce98032 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:08:37.856776 [ 16756 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDhhmmssToDateTime64'. Expected 1 mandatory argument and 2 optional arguments, got 4 arguments: In scope SELECT YYYYMMDDhhmmssToDateTime64(20230911134254, 3, 'Europe/Berlin', 'no more args'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000012c9192b 4. /build/src/Functions/FunctionHelpers.cpp:184: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c90171 5. /build/src/Functions/makeDate.cpp:656: DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ce98032 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:08:37.862278 [ 4930 ] {f0bc47c3-f706-4ed4-bf49-5cd8061dfc04} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48844) (comment: 03203_system_query_metric_log.sh) (query 2, line 3) (in query: SELECT count() BETWEEN ((ceil(2500 / 1000) - 1) * 0.2) AND ((ceil(2500 / 1000) + 1) * 1.8) FROM system.query_metric_log WHERE event_date >= yesterday() AND query_id = 'test_80w0omk3_1000' ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x00000000163993d1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016396620 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001639641f 10. /build/src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000163b2bd7 11. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x00000000162ea22d 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x00000000162e6974 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x00000000163d9d66 14. /build/src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x0000000016d7885f 15. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x0000000016d9cdca 16. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5520 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 18. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 22. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 23. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:08:37.869539 [ 6608 ] {ef3a866b-5658-4a8b-88ea-a890ce6b9734} executeQuery: Code: 57. DB::Exception: Table test_3.test_table already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48864) (comment: 02540_analyzer_matcher_alias_materialized_columns.sql) (query 3, line 4) (in query: CREATE TABLE test_table (`id` UInt64, `value_alias` ALIAS concat('AliasValue_', toString(id)), `value_materialized` MATERIALIZED concat('MaterializedValue_', toString(id))) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 21330, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 38, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 433830059, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 17696549, merge_max_block_size = 21448, 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 = 551209, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = true, marks_compress_block_size = 15826, primary_key_compress_block_size = 77060, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:08:37.904825 [ 6608 ] {} TCPHandler: Code: 57. DB::Exception: Table test_3.test_table already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:08:37.936993 [ 4930 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x00000000163993d1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016396620 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001639641f 10. /build/src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000163b2bd7 11. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x00000000162ea22d 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x00000000162e6974 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x00000000163d9d66 14. /build/src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x0000000016d7885f 15. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x0000000016d9cdca 16. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5520 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 18. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 22. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 23. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:08:38.774171 [ 11482 ] {c4245ebe-3c73-4d32-8643-44130696c917} InterpreterCheckQuery: Check query for table test_1.tp_1 (117c9ab7-5c62-4569-805e-002fd7d8b232) failed, path 0_1_1_0, reason: Code: 227. DB::Exception: Found unexpected projection directories: pp.proj. (UNEXPECTED_FILE_IN_DATA_PART) (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:08:38.792643 [ 6614 ] {2eefb326-dee6-456b-9b9b-4b0c1677874f} 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]:47326) (comment: 02890_describe_table_options.sql) (in query: DROP DATABASE IF EXISTS test_5hevfwpf SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:08:38.926381 [ 6614 ] {2eefb326-dee6-456b-9b9b-4b0c1677874f} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:08:39.481348 [ 5121 ] {60dba176-431a-4355-8ddc-a36c3847af68} executeQuery: Code: 159. DB::Exception: Timeout exceeded (180 s) while flushing system log 'DB::SystemLogQueue'. (TIMEOUT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60490) (comment: 03002_part_log_rmt_fetch_mutate_error.sh) (query 2, line 4) (in query: system flush logs;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Common/SystemLogBase.cpp:168: DB::SystemLogQueue::waitFlush(long, bool) @ 0x000000000fbee407 5. /build/src/Interpreters/SystemLog.cpp:437: DB::SystemLogs::flush(bool, std::vector> const&) @ 0x0000000014a1ea9f 6. /build/src/Interpreters/InterpreterSystemQuery.cpp:796: DB::InterpreterSystemQuery::execute() @ 0x0000000014bd5a4e 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:08:39.636474 [ 5121 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded (180 s) while flushing system log 'DB::SystemLogQueue'. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Common/SystemLogBase.cpp:168: DB::SystemLogQueue::waitFlush(long, bool) @ 0x000000000fbee407 5. /build/src/Interpreters/SystemLog.cpp:437: DB::SystemLogs::flush(bool, std::vector> const&) @ 0x0000000014a1ea9f 6. /build/src/Interpreters/InterpreterSystemQuery.cpp:796: DB::InterpreterSystemQuery::execute() @ 0x0000000014bd5a4e 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:08:39.802191 [ 12981 ] {3e72747a-00aa-44e6-bdee-6f2c6cd04a69} InterpreterCheckQuery: Check query for table test_1.tp_1 (117c9ab7-5c62-4569-805e-002fd7d8b232) failed, path 0_1_1_0, reason: Code: 227. DB::Exception: Found unexpected projection directories: pp.proj. (UNEXPECTED_FILE_IN_DATA_PART) (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:08:41.278093 [ 11525 ] {} test_1.tp_1 (117c9ab7-5c62-4569-805e-002fd7d8b232): Cannot quickly remove directory /var/lib/clickhouse/store/117/117c9ab7-5c62-4569-805e-002fd7d8b232/delete_tmp_0_1_1_0/pp.proj by removing files; fallback to recursive removal. Reason: Code: 458. DB::ErrnoException: Cannot unlink file /var/lib/clickhouse/store/117/117c9ab7-5c62-4569-805e-002fd7d8b232/delete_tmp_0_1_1_0/pp.proj/x.cmrk2: , errno: 2, strerror: No such file or directory. (CANNOT_UNLINK) (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:08:42.034621 [ 6166 ] {266cb28e-7ad8-4a7e-92cf-75bcad6dd755} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 60178.526718 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37846) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x0000000013ad84ab 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x0000000013ad77ec 5. /build/src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x000000001496af1f 6. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000168d1a5a 7. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0c24 8. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168cfe81 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 2025.07.13 02:08:42.096011 [ 6166 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 60178.526718 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x0000000013ad84ab 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x0000000013ad77ec 5. /build/src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x000000001496af1f 6. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000168d1a5a 7. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0c24 8. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168cfe81 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x00000000168cf907 5. /build/src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000001680710e 6. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 2025.07.13 02:08:43.169102 [ 16756 ] {08f85b64-9039-476e-b4c1-3dfb028192dc} executeQuery: Code: 36. DB::Exception: Argument for function YYYYMMDDhhmmssToDateTime64 must be finite: In scope SELECT YYYYMMDDhhmmssToDateTime64(nan). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46868) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (query 86, line 101) (in query: SELECT YYYYMMDDhhmmssToDateTime64(NaN);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/makeDate.cpp:697: DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ce97d62 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:08:43.197115 [ 16756 ] {} TCPHandler: Code: 36. DB::Exception: Argument for function YYYYMMDDhhmmssToDateTime64 must be finite: In scope SELECT YYYYMMDDhhmmssToDateTime64(nan). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/makeDate.cpp:697: DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ce97d62 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:08:43.504258 [ 16756 ] {e3b7f638-c65f-465c-984e-711760d3e55a} executeQuery: Code: 36. DB::Exception: Argument for function YYYYMMDDhhmmssToDateTime64 must be finite: In scope SELECT YYYYMMDDhhmmssToDateTime64(inf). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46868) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (query 87, line 102) (in query: SELECT YYYYMMDDhhmmssToDateTime64(Inf);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/makeDate.cpp:697: DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ce97d62 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:08:43.513462 [ 16756 ] {} TCPHandler: Code: 36. DB::Exception: Argument for function YYYYMMDDhhmmssToDateTime64 must be finite: In scope SELECT YYYYMMDDhhmmssToDateTime64(inf). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/makeDate.cpp:697: DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ce97d62 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:08:43.627322 [ 16756 ] {a88b0903-8748-4b72-b8f3-416dd76365c7} executeQuery: Code: 36. DB::Exception: Argument for function YYYYMMDDhhmmssToDateTime64 must be finite: In scope SELECT YYYYMMDDhhmmssToDateTime64(-inf). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46868) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (query 88, line 103) (in query: SELECT YYYYMMDDhhmmssToDateTime64(-Inf);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/makeDate.cpp:697: DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ce97d62 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:08:43.659914 [ 16756 ] {} TCPHandler: Code: 36. DB::Exception: Argument for function YYYYMMDDhhmmssToDateTime64 must be finite: In scope SELECT YYYYMMDDhhmmssToDateTime64(-inf). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/makeDate.cpp:697: DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ce97d62 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:08:44.472750 [ 5998 ] {bf583a53-21e9-4cb5-aee9-0b8dbc12db48} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 46 (numbers): numbers. Expected one of: token, 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]:57158) (comment: 00956_sensitive_data_masking.sh) (in query: SELECT 'find_me_[hidden]' FRRRROM numbers), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000009fd29ed 3. /build/src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9acc 4. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 5. /build/src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba32be 6. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 7. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 8. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 9. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:08:44.508263 [ 5998 ] {bf583a53-21e9-4cb5-aee9-0b8dbc12db48} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 46 (numbers): numbers. Expected one of: token, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000009fd29ed 3. /build/src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9acc 4. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 5. /build/src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba32be 6. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 7. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 8. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 9. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:08:45.321259 [ 5987 ] {fc3a083e-31e1-48df-ad9d-490c513d1dc6} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `credit_card_number` in scope SELECT 1 FROM system.numbers WHERE credit_card_number = 'find_me_[hidden]'. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52600) (comment: 00956_sensitive_data_masking.sh) (query 1, line 1) (in query: SELECT 1 FROM system.numbers WHERE credit_card_number='find_me_[hidden]' FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000013f69e39 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f3a889 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3236a 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 16. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:08:45.400730 [ 5987 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `credit_card_number` in scope SELECT 1 FROM system.numbers WHERE credit_card_number = 'find_me_[hidden]'. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000013f69e39 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f3a889 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3236a 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 16. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:08:45.837572 [ 5998 ] {05b73e7e-cabf-4224-93cf-23e55a236985} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `credit_card_number` in scope SELECT 1 FROM system.numbers WHERE credit_card_number = 'find_me_[hidden]'. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:57162) (comment: 00956_sensitive_data_masking.sh) (in query: SELECT 1 FROM system.numbers WHERE credit_card_number='find_me_[hidden]' FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000013f69e39 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f3a889 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3236a 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 16. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 17. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 18. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 19. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 20. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 2025.07.13 02:08:45.854011 [ 5998 ] {05b73e7e-cabf-4224-93cf-23e55a236985} DynamicQueryHandler: Code: 47. DB::Exception: Unknown expression or function identifier `credit_card_number` in scope SELECT 1 FROM system.numbers WHERE credit_card_number = 'find_me_[hidden]'. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000013f69e39 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f3a889 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3236a 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 16. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 17. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 18. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 19. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 20. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:08:45.971709 [ 4912 ] {862e10b2-5ffd-440b-ba67-7f3c3f5fbca7} 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]:52644) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: CREATE TABLE src (`A` UInt64) ENGINE = ReplicatedMergeTree('/clickhouse/{database}/test/src1', '1') ORDER BY tuple() SETTINGS min_bytes_for_wide_part = 0, index_granularity = 9719, 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 = 250708176, compact_parts_max_bytes_to_buffer = 292707085, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 32066546, merge_max_block_size = 22893, old_parts_lifetime = 30., 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 = 15135751, use_const_adaptive_granularity = false, 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 = 65335, primary_key_compress_block_size = 67643, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000013cc1696 5. /build/src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013cc32f5 6. /build/src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc384b 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:08:46.021937 [ 4912 ] {} TCPHandler: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000013cc1696 5. /build/src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013cc32f5 6. /build/src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc384b 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:08:46.534165 [ 16758 ] {e7edd232-039e-476e-b0ba-f8eb39156376} executeQuery: Code: 60. DB::Exception: Table test_qm5wpv27.src does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52672) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: insert into src values ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013cf9b5f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144148c9 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001441ace8 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001484a2e4 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014851d18 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:08:46.572486 [ 16758 ] {} TCPHandler: Code: 60. DB::Exception: Table test_qm5wpv27.src does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013cf9b5f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144148c9 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001441ace8 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001484a2e4 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014851d18 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:08:46.865039 [ 4912 ] {461965ef-183a-402a-a4da-20fa91051ceb} executeQuery: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION intDiv(100_UInt8 :: 1, minus(__table1.number, 10_UInt8) :: 0) -> intDiv(100_UInt8, minus(__table1.number, 10_UInt8)) Int8 : 2'. (ILLEGAL_DIVISION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52656) (comment: 00956_sensitive_data_masking.sh) (query 1, line 1) (in query: SELECT 'find_me_[hidden]', intDiv( 100, number - 10) FROM numbers(11) FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::throwIfDivisionLeadsToFPE<_BitInt(8), long>(_BitInt(8), long) @ 0x000000000b95c739 5. /build/src/Functions/DivisionUtils.h:48: void DB::impl_::BinaryOperation, _BitInt(8)>::process<(DB::impl_::OpCase)1>(char8_t const*, long const*, DB::impl_::BinaryOperation, _BitInt(8)>*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000c1a81a4 6. /build/src/Functions/FunctionBinaryArithmetic.h:2338: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000c3d8e38 7. /build/src/Functions/FunctionBinaryArithmetic.h:2508: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000c3d40d1 8. /build/src/Functions/FunctionBinaryArithmetic.h:846: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000c3d3087 9. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000c3cf585 10. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c3cdb0c 11. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c3cc994 12. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 13. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 17. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 18. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 19. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 20. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 21. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 22. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 23. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 24. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 25. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:08:46.951211 [ 4912 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION intDiv(100_UInt8 :: 1, minus(__table1.number, 10_UInt8) :: 0) -> intDiv(100_UInt8, minus(__table1.number, 10_UInt8)) Int8 : 2'. (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::throwIfDivisionLeadsToFPE<_BitInt(8), long>(_BitInt(8), long) @ 0x000000000b95c739 5. /build/src/Functions/DivisionUtils.h:48: void DB::impl_::BinaryOperation, _BitInt(8)>::process<(DB::impl_::OpCase)1>(char8_t const*, long const*, DB::impl_::BinaryOperation, _BitInt(8)>*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000c1a81a4 6. /build/src/Functions/FunctionBinaryArithmetic.h:2338: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000c3d8e38 7. /build/src/Functions/FunctionBinaryArithmetic.h:2508: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000c3d40d1 8. /build/src/Functions/FunctionBinaryArithmetic.h:846: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000c3d3087 9. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000c3cf585 10. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c3cdb0c 11. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c3cc994 12. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 13. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 17. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 18. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 19. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 20. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 21. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 22. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 23. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 24. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 25. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:08:47.363497 [ 16758 ] {d08dd65a-4868-4f2a-8e1e-6fb553513b90} executeQuery: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52682) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src detach partition tuple()), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fdd59 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:08:47.400050 [ 16758 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fdd59 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:08:47.935238 [ 3543 ] {f6ee10c6-7370-422c-827f-00d4b6bc2a39} executeQuery: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52714) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src attach partition tuple()), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fdd59 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:08:47.977699 [ 3543 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fdd59 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:08:48.660757 [ 6619 ] {409c540a-dcb4-4462-8304-cd9050c12758} executeQuery: Code: 60. DB::Exception: Table test_qm5wpv27.src does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52750) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src update A = 1 where 1 settings mutations_sync=2), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013cf9b5f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144148c9 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001441ace8 7. /build/src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x0000000013cd7e42 8. /build/src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013cd7a7f 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fbcf4 10. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:08:48.702598 [ 6619 ] {} TCPHandler: Code: 60. DB::Exception: Table test_qm5wpv27.src does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013cf9b5f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144148c9 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001441ace8 7. /build/src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x0000000013cd7e42 8. /build/src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013cd7a7f 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fbcf4 10. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:08:49.308874 [ 6619 ] {9a6fa245-3372-4af2-adc8-d024beff2b4f} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'src' in scope SELECT throwIf(A != 1) FROM src. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34020) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: select throwIf(A != 1) from src format Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f633d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:08:49.348253 [ 6619 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'src' in scope SELECT throwIf(A != 1) FROM src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f633d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:08:49.860933 [ 16763 ] {f8541414-b478-4283-b88d-cf755cbd7f37} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52706) (comment: 00956_sensitive_data_masking.sh) (query 1, line 1) (in query: select sleepEachRow(1) from numbers(10) where ignore('find_me_[hidden]')=0 and ignore('fwerkh_that_magic_string_make_me_unique') = 0 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000001496a8c5 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000001496a819 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x000000001496af0d 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000168d1a5a 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0c24 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 12. ? @ 0x00007f7210eb6ac3 13. ? @ 0x00007f7210f48850 2025.07.13 02:08:49.922978 [ 16763 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000001496a8c5 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000001496a819 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x000000001496af0d 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000168d1a5a 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0c24 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 12. ? @ 0x00007f7210eb6ac3 13. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:08:49.954000 [ 6619 ] {725cc4b1-5146-4d3f-b7b4-e80c01e9ee86} executeQuery: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34048) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src detach partition tuple()), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fdd59 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:08:50.001155 [ 6619 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fdd59 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:08:50.652835 [ 16763 ] {4a0f13e4-4263-4756-9c69-02cb3e5da883} executeQuery: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34080) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src attach partition tuple()), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fdd59 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:08:50.716594 [ 16763 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fdd59 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:08:51.432001 [ 4888 ] {a52f45da-8aac-4896-afff-63f0bc7c7a39} executeQuery: Code: 60. DB::Exception: Table test_qm5wpv27.src does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34106) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src update A = 2 where 1 settings mutations_sync=2), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013cf9b5f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144148c9 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001441ace8 7. /build/src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x0000000013cd7e42 8. /build/src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013cd7a7f 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fbcf4 10. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:08:51.490667 [ 4888 ] {} TCPHandler: Code: 60. DB::Exception: Table test_qm5wpv27.src does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013cf9b5f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144148c9 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001441ace8 7. /build/src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x0000000013cd7e42 8. /build/src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013cd7a7f 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fbcf4 10. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:08:51.991312 [ 4888 ] {} TCPHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000013779f8b 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000137794b8 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778c58 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168167bf 10. /build/src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000001680ff45 11. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:08:51.993635 [ 4888 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x0000000016810069 5. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 6. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 2025.07.13 02:08:52.015812 [ 4930 ] {33c4064d-d077-46a1-b54f-fc16de496d48} executeQuery: Code: 452. DB::Exception: Received from 127.1:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000013779f8b 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000137794b8 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778c58 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168167bf 10. /build/src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000001680ff45 11. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34118) (comment: 01932_remote_sharding_key_column.sql) (query 1, line 3) (in query: -- regression test for the following query: -- -- select * from remote('127.1', system.one, dummy) -- -- that produce the following error before: -- -- Unknown column: dummy, there are only columns . -- -- NOTE: that wrapping column into any function works before. select * from remote('127.1', system.one, dummy) format Null;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fb80677 3. /build/src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x00000000166f5247 4. /build/src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000166fc432 5. /build/src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001673a5f3 6. /build/src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013af6952 7. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013af679a 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013af64e1 2025.07.13 02:08:52.103854 [ 5987 ] {425da296-c96e-46d4-9242-db3d658114da} executeQuery: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52628) (comment: 00093_union_race_conditions_4.sh) (query 1, line 1) (in query: SELECT 1 % ((number + 500) % 1000) FROM numbers_mt(1000);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000d09b541 5. /build/src/Functions/FunctionBinaryArithmetic.h:2338: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d2bd336 6. /build/src/Functions/FunctionBinaryArithmetic.h:2508: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d2bb988 7. /build/src/Functions/FunctionBinaryArithmetic.h:846: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d2bade7 8. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d2b72e5 9. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d2b586c 10. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d2b4af4 11. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 22. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:08:52.105083 [ 4930 ] {} TCPHandler: Code: 452. DB::Exception: Received from 127.1:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000013779f8b 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000137794b8 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778c58 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168167bf 10. /build/src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000001680ff45 11. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fb80677 3. /build/src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x00000000166f5247 4. /build/src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000166fc432 5. /build/src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001673a5f3 6. /build/src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013af6952 7. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013af679a 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013af64e1 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:08:52.195801 [ 5987 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000d09b541 5. /build/src/Functions/FunctionBinaryArithmetic.h:2338: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d2bd336 6. /build/src/Functions/FunctionBinaryArithmetic.h:2508: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d2bb988 7. /build/src/Functions/FunctionBinaryArithmetic.h:846: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d2bade7 8. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d2b72e5 9. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d2b586c 10. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d2b4af4 11. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 22. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:08:52.309456 [ 5121 ] {572d9791-b7bc-4eef-a6a9-d4b375a4859b} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'src' in scope SELECT throwIf(A != 2) FROM src. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34146) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: select throwIf(A != 2) from src format Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f633d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:08:52.376717 [ 5121 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'src' in scope SELECT throwIf(A != 2) FROM src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f633d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:08:53.153200 [ 5121 ] {4374f78d-c950-4706-baa1-7f951dbc08fc} executeQuery: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34186) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src detach partition tuple()), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fdd59 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:08:53.197580 [ 5121 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fdd59 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:08:53.828949 [ 6532 ] {2eff000f-5876-47d9-a74b-a06b72729d3b} executeQuery: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34200) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src attach partition tuple()), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fdd59 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:08:53.882647 [ 6532 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fdd59 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:08:54.435962 [ 6168 ] {82148559-47ec-4f7a-8ab6-39ff92143ee1} executeQuery: Code: 60. DB::Exception: Table test_qm5wpv27.src does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34224) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src update A = 3 where 1 settings mutations_sync=2), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013cf9b5f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144148c9 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001441ace8 7. /build/src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x0000000013cd7e42 8. /build/src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013cd7a7f 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fbcf4 10. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:08:54.524447 [ 6168 ] {} TCPHandler: Code: 60. DB::Exception: Table test_qm5wpv27.src does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013cf9b5f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144148c9 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001441ace8 7. /build/src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x0000000013cd7e42 8. /build/src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013cd7a7f 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fbcf4 10. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:08:55.383143 [ 6168 ] {23b08fe1-0c86-45f7-a4d0-a334bf81d896} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'src' in scope SELECT throwIf(A != 3) FROM src. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34238) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: select throwIf(A != 3) from src format Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f633d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:08:55.444341 [ 6168 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'src' in scope SELECT throwIf(A != 3) FROM src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f633d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:08:56.147406 [ 5121 ] {246e1541-be98-47c1-b796-b045b23dd0a2} executeQuery: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34266) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src detach partition tuple()), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fdd59 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:08:56.213700 [ 5121 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fdd59 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:08:56.811747 [ 5121 ] {3f8ac32a-916b-40a9-a3e6-cfbed8a33e3f} executeQuery: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34312) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src attach partition tuple()), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fdd59 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:08:56.845436 [ 5121 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fdd59 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:08:57.511404 [ 16784 ] {db7a3802-2812-43e3-bc6d-f6febc222d44} executeQuery: Code: 60. DB::Exception: Table test_qm5wpv27.src does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34342) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src update A = 4 where 1 settings mutations_sync=2), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013cf9b5f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144148c9 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001441ace8 7. /build/src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x0000000013cd7e42 8. /build/src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013cd7a7f 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fbcf4 10. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:08:57.588631 [ 16784 ] {} TCPHandler: Code: 60. DB::Exception: Table test_qm5wpv27.src does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013cf9b5f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144148c9 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001441ace8 7. /build/src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x0000000013cd7e42 8. /build/src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013cd7a7f 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fbcf4 10. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:08:58.138485 [ 6532 ] {caf4c3f5-842b-4fa6-9f58-66767b24a2ae} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'src' in scope SELECT throwIf(A != 4) FROM src. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34354) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: select throwIf(A != 4) from src format Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f633d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:08:58.187491 [ 6532 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'src' in scope SELECT throwIf(A != 4) FROM src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f633d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:08:58.699320 [ 5987 ] {d02999db-6473-4f06-88ad-a1ef65fc19b4} executeQuery: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34174) (comment: 00093_union_race_conditions_4.sh) (query 1, line 1) (in query: SELECT 1 % ((number + 500) % 1000) FROM numbers_mt(1000);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000d09b541 5. /build/src/Functions/FunctionBinaryArithmetic.h:2338: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d2bd336 6. /build/src/Functions/FunctionBinaryArithmetic.h:2508: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d2bb988 7. /build/src/Functions/FunctionBinaryArithmetic.h:846: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d2bade7 8. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d2b72e5 9. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d2b586c 10. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d2b4af4 11. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 22. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:08:58.732804 [ 5987 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000d09b541 5. /build/src/Functions/FunctionBinaryArithmetic.h:2338: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d2bd336 6. /build/src/Functions/FunctionBinaryArithmetic.h:2508: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d2bb988 7. /build/src/Functions/FunctionBinaryArithmetic.h:846: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d2bade7 8. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d2b72e5 9. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d2b586c 10. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d2b4af4 11. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 22. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:08:58.815356 [ 6532 ] {417ec322-8494-4a0b-bfed-c5005016aaab} executeQuery: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34374) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src detach partition tuple()), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fdd59 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:08:58.886035 [ 6532 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fdd59 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:08:58.943808 [ 4896 ] {e325fec5-d7a0-45ba-8325-6b5a5c474cdc} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max rows: 100.00, current rows: 48.01 thousand. (TOO_MANY_ROWS_OR_BYTES) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34362) (comment: 01131_max_rows_to_sort.sql) (query 2, line 2) (in query: SELECT * FROM system.numbers ORDER BY number;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000013af9d2b 4. /build/src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013af96d2 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000016b4227b 6. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 7. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 10. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 11. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 12. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:08:59.038705 [ 4896 ] {} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max rows: 100.00, current rows: 48.01 thousand. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000013af9d2b 4. /build/src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013af96d2 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000016b4227b 6. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 7. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 10. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 11. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 12. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:08:59.403981 [ 6532 ] {9f48e751-2f5a-49f5-943f-0b0461e3c453} executeQuery: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59684) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src attach partition tuple()), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fdd59 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:08:59.404707 [ 4896 ] {e4d170a0-5e41-4fc6-8b33-b99af8ac2c58} 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]:34362) (comment: 01131_max_rows_to_sort.sql) (query 4, line 5) (in query: SET max_block_size = 1000;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/executeQuery.cpp:1338: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba8300 5. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 6. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 7. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 12. ? @ 0x00007f7210eb6ac3 13. ? @ 0x00007f7210f48850 2025.07.13 02:08:59.413065 [ 3543 ] {df17a556-37cd-455a-9890-04a42303d4c6} 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]:52742) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Interpreters/ActionsDAG.cpp:1282: DB::ActionsDAG::appendInputsForUnusedColumns(DB::Block const&) @ 0x0000000013ec653f 5. /build/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_ @ 0x00000000148beb4f 6. /build/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&) @ 0x00000000148bc373 7. /build/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&) @ 0x00000000148adbec 8. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 9. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:08:59.426779 [ 3543 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Interpreters/ActionsDAG.cpp:1282: DB::ActionsDAG::appendInputsForUnusedColumns(DB::Block const&) @ 0x0000000013ec653f 5. /build/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_ @ 0x00000000148beb4f 6. /build/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&) @ 0x00000000148bc373 7. /build/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&) @ 0x00000000148adbec 8. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 9. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:08:59.520009 [ 6532 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fdd59 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:08:59.525318 [ 4896 ] {} TCPHandler: Code: 731. DB::Exception: use_query_cache and overflow_mode != 'throw' cannot be used together. (QUERY_CACHE_USED_WITH_NON_THROW_OVERFLOW_MODE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/executeQuery.cpp:1338: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba8300 5. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 6. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 7. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 12. ? @ 0x00007f7210eb6ac3 13. ? @ 0x00007f7210f48850 2025.07.13 02:09:00.207351 [ 6532 ] {64e86f4b-c8dc-48d3-869f-4cfc8b1c118a} executeQuery: Code: 60. DB::Exception: Table test_qm5wpv27.src does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59692) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src update A = 5 where 1 settings mutations_sync=2), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013cf9b5f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144148c9 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001441ace8 7. /build/src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x0000000013cd7e42 8. /build/src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013cd7a7f 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fbcf4 10. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:09:00.234983 [ 6532 ] {} TCPHandler: Code: 60. DB::Exception: Table test_qm5wpv27.src does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013cf9b5f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144148c9 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001441ace8 7. /build/src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x0000000013cd7e42 8. /build/src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013cd7a7f 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fbcf4 10. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:09:00.498602 [ 3542 ] {26c5274d-3512-46e2-9b75-38b52c00ae0f} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51472) (comment: 01018_ip_dictionary_long.sql) (query 342, line 464) (in query: DROP DICTIONARY IF EXISTS test_07omevd0.dict_ip_trie), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833ede 5. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 7. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 10. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:09:00.541964 [ 3542 ] {} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833ede 5. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 7. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 10. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:09:00.688098 [ 5121 ] {a3855085-b774-45f9-9372-26f990e7e45b} executeQuery: Code: 43. DB::Exception: Parameter #0 'scale' for DateTime64 has wrong type: String, expected UInt64 literal: In scope SELECT CAST(1, 'DateTime64(\'abc\')'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59694) (comment: 00921_datetime64_basic.sql) (query 2, line 3) (in query: SELECT CAST(1 as DateTime64('abc'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/DataTypes/registerDataTypeDateTime.cpp:50: std::conditional<(DB::ArgumentKind)1 == (DB::ArgumentKind)0, std::optional, unsigned long>::type DB::getArgument(std::shared_ptr const&, unsigned long, char const*, String) @ 0x0000000013b9b7b2 4. /build/src/DataTypes/registerDataTypeDateTime.cpp:103: DB::create64(std::shared_ptr const&) @ 0x0000000013b9af95 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013b0e25b 6. /build/src/DataTypes/DataTypeFactory.cpp:91: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000013b0dcfe 7. /build/src/DataTypes/DataTypeFactory.cpp:73: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x0000000013b0d9d2 8. /build/src/Functions/CastOverloadResolver.cpp:127: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012cb7dad 9. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 10. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80f9b 11. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:09:00.765375 [ 5121 ] {} TCPHandler: Code: 43. DB::Exception: Parameter #0 'scale' for DateTime64 has wrong type: String, expected UInt64 literal: In scope SELECT CAST(1, 'DateTime64(\'abc\')'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/DataTypes/registerDataTypeDateTime.cpp:50: std::conditional<(DB::ArgumentKind)1 == (DB::ArgumentKind)0, std::optional, unsigned long>::type DB::getArgument(std::shared_ptr const&, unsigned long, char const*, String) @ 0x0000000013b9b7b2 4. /build/src/DataTypes/registerDataTypeDateTime.cpp:103: DB::create64(std::shared_ptr const&) @ 0x0000000013b9af95 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013b0e25b 6. /build/src/DataTypes/DataTypeFactory.cpp:91: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000013b0dcfe 7. /build/src/DataTypes/DataTypeFactory.cpp:73: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x0000000013b0d9d2 8. /build/src/Functions/CastOverloadResolver.cpp:127: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012cb7dad 9. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 10. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80f9b 11. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:09:00.903426 [ 16763 ] {f1e9ffef-fe52-4a92-a947-52af74a6d819} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'src' in scope SELECT throwIf(A != 5) FROM src. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59700) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: select throwIf(A != 5) from src format Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f633d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:09:00.944376 [ 16763 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'src' in scope SELECT throwIf(A != 5) FROM src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f633d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:09:01.023010 [ 6619 ] {9e140610-9507-4813-9a6e-de2784d5cccc} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43046) (comment: 01018_ip_dictionary_long.sql) (in query: DROP DATABASE IF EXISTS test_07omevd0 SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833ede 5. /build/src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835a47 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:09:01.071571 [ 6619 ] {9e140610-9507-4813-9a6e-de2784d5cccc} DynamicQueryHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833ede 5. /build/src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835a47 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:09:01.167051 [ 5121 ] {877a870a-75cd-4534-bcd8-66f89470d800} executeQuery: Code: 69. DB::Exception: Scale 100 is out of bounds (max scale: 18): In scope SELECT CAST(1, 'DateTime64(100)'). (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59694) (comment: 00921_datetime64_basic.sql) (query 3, line 4) (in query: SELECT CAST(1 as DateTime64(100));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000009fb386b 4. /build/src/DataTypes/DataTypeDecimalBase.h:77: DB::DataTypeDecimalBase::DataTypeDecimalBase(unsigned int, unsigned int) @ 0x0000000013b039e5 5. /build/src/DataTypes/DataTypeDateTime64.cpp:21: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x0000000013b0175c 6. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], unsigned long const&, String, 0>(std::allocator const&, unsigned long const&, String&&) @ 0x0000000013b9b2e6 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create64(std::shared_ptr const&) @ 0x0000000013b9b108 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013b0e25b 9. /build/src/DataTypes/DataTypeFactory.cpp:91: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000013b0dcfe 10. /build/src/DataTypes/DataTypeFactory.cpp:73: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x0000000013b0d9d2 11. /build/src/Functions/CastOverloadResolver.cpp:127: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012cb7dad 12. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 13. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80f9b 14. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 29. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 30. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 2025.07.13 02:09:01.227882 [ 5121 ] {} TCPHandler: Code: 69. DB::Exception: Scale 100 is out of bounds (max scale: 18): In scope SELECT CAST(1, 'DateTime64(100)'). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000009fb386b 4. /build/src/DataTypes/DataTypeDecimalBase.h:77: DB::DataTypeDecimalBase::DataTypeDecimalBase(unsigned int, unsigned int) @ 0x0000000013b039e5 5. /build/src/DataTypes/DataTypeDateTime64.cpp:21: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x0000000013b0175c 6. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], unsigned long const&, String, 0>(std::allocator const&, unsigned long const&, String&&) @ 0x0000000013b9b2e6 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create64(std::shared_ptr const&) @ 0x0000000013b9b108 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013b0e25b 9. /build/src/DataTypes/DataTypeFactory.cpp:91: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000013b0dcfe 10. /build/src/DataTypes/DataTypeFactory.cpp:73: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x0000000013b0d9d2 11. /build/src/Functions/CastOverloadResolver.cpp:127: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012cb7dad 12. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 13. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80f9b 14. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 29. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 30. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 2025.07.13 02:09:01.556399 [ 5121 ] {c1391f34-1862-42d1-b856-30d7c5d2cc60} executeQuery: Code: 43. DB::Exception: Parameter #0 'scale' for DateTime64 has wrong type: Int64, expected UInt64 literal: In scope SELECT CAST(1, 'DateTime64(-1)'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59694) (comment: 00921_datetime64_basic.sql) (query 4, line 5) (in query: SELECT CAST(1 as DateTime64(-1));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/DataTypes/registerDataTypeDateTime.cpp:50: std::conditional<(DB::ArgumentKind)1 == (DB::ArgumentKind)0, std::optional, unsigned long>::type DB::getArgument(std::shared_ptr const&, unsigned long, char const*, String) @ 0x0000000013b9b7b2 4. /build/src/DataTypes/registerDataTypeDateTime.cpp:103: DB::create64(std::shared_ptr const&) @ 0x0000000013b9af95 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013b0e25b 6. /build/src/DataTypes/DataTypeFactory.cpp:91: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000013b0dcfe 7. /build/src/DataTypes/DataTypeFactory.cpp:73: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x0000000013b0d9d2 8. /build/src/Functions/CastOverloadResolver.cpp:127: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012cb7dad 9. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 10. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80f9b 11. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:09:01.564227 [ 5121 ] {} TCPHandler: Code: 43. DB::Exception: Parameter #0 'scale' for DateTime64 has wrong type: Int64, expected UInt64 literal: In scope SELECT CAST(1, 'DateTime64(-1)'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/DataTypes/registerDataTypeDateTime.cpp:50: std::conditional<(DB::ArgumentKind)1 == (DB::ArgumentKind)0, std::optional, unsigned long>::type DB::getArgument(std::shared_ptr const&, unsigned long, char const*, String) @ 0x0000000013b9b7b2 4. /build/src/DataTypes/registerDataTypeDateTime.cpp:103: DB::create64(std::shared_ptr const&) @ 0x0000000013b9af95 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013b0e25b 6. /build/src/DataTypes/DataTypeFactory.cpp:91: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000013b0dcfe 7. /build/src/DataTypes/DataTypeFactory.cpp:73: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x0000000013b0d9d2 8. /build/src/Functions/CastOverloadResolver.cpp:127: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012cb7dad 9. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 10. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80f9b 11. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:09:01.643877 [ 6619 ] {2838a174-bd31-4e3e-b25a-009dd0a46d6c} executeQuery: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59716) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src detach partition tuple()), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fdd59 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:09:01.662116 [ 6619 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fdd59 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:09:01.893067 [ 5121 ] {cc7360be-e597-4d5d-9afc-e770b3106377} executeQuery: Code: 36. DB::Exception: Cannot load time zone qqq: In scope SELECT CAST(1, 'DateTime64(3, \'qqq\')'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59694) (comment: 00921_datetime64_basic.sql) (query 5, line 6) (in query: SELECT CAST(1 as DateTime64(3, 'qqq'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x000000000faae8c8 5. /build/src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x000000000faaaf5e 6. /build/src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x0000000013b01446 7. /build/src/DataTypes/DataTypeDateTime64.cpp:22: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x0000000013b01768 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], unsigned long const&, String, 0>(std::allocator const&, unsigned long const&, String&&) @ 0x0000000013b9b2e6 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create64(std::shared_ptr const&) @ 0x0000000013b9b108 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013b0e25b 11. /build/src/DataTypes/DataTypeFactory.cpp:91: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000013b0dcfe 12. /build/src/DataTypes/DataTypeFactory.cpp:73: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x0000000013b0d9d2 13. /build/src/Functions/CastOverloadResolver.cpp:127: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012cb7dad 14. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 15. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80f9b 16. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 31. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 2025.07.13 02:09:01.905841 [ 5121 ] {} TCPHandler: Code: 36. DB::Exception: Cannot load time zone qqq: In scope SELECT CAST(1, 'DateTime64(3, \'qqq\')'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x000000000faae8c8 5. /build/src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x000000000faaaf5e 6. /build/src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x0000000013b01446 7. /build/src/DataTypes/DataTypeDateTime64.cpp:22: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x0000000013b01768 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], unsigned long const&, String, 0>(std::allocator const&, unsigned long const&, String&&) @ 0x0000000013b9b2e6 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create64(std::shared_ptr const&) @ 0x0000000013b9b108 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013b0e25b 11. /build/src/DataTypes/DataTypeFactory.cpp:91: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000013b0dcfe 12. /build/src/DataTypes/DataTypeFactory.cpp:73: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x0000000013b0d9d2 13. /build/src/Functions/CastOverloadResolver.cpp:127: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012cb7dad 14. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 15. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80f9b 16. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 31. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 2025.07.13 02:09:02.196651 [ 5121 ] {085de5e0-1594-463a-8cf5-8aad03eabc77} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDateTime64'. Expected: const Integer, got: String: In scope SELECT toDateTime64('2019-09-16 19:20:11.234', 'abc'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59694) (comment: 00921_datetime64_basic.sql) (query 6, line 8) (in query: SELECT toDateTime64('2019-09-16 19:20:11.234', 'abc');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/FunctionsConversion.h:2234: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x0000000012eb031d 7. /build/src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012eb0115 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 9. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 25. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 26. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 31. ? @ 0x00007f7210eb6ac3 2025.07.13 02:09:02.234465 [ 5121 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDateTime64'. Expected: const Integer, got: String: In scope SELECT toDateTime64('2019-09-16 19:20:11.234', 'abc'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/FunctionsConversion.h:2234: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x0000000012eb031d 7. /build/src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012eb0115 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 9. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 25. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 26. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 31. ? @ 0x00007f7210eb6ac3 2025.07.13 02:09:02.276441 [ 6619 ] {9e869c0b-cb1d-47dc-82e1-efa940495a7a} executeQuery: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59740) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src attach partition tuple()), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fdd59 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:09:02.322560 [ 6619 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fdd59 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:09:02.820421 [ 5121 ] {62be8b05-cbf5-4626-af6e-675e1b549df7} executeQuery: Code: 69. DB::Exception: Scale 100 is out of bounds (max scale: 18): In scope SELECT toDateTime64('2019-09-16 19:20:11.234', 100). (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59694) (comment: 00921_datetime64_basic.sql) (query 7, line 9) (in query: SELECT toDateTime64('2019-09-16 19:20:11.234', 100);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000009fb386b 4. /build/src/DataTypes/DataTypeDecimalBase.h:77: DB::DataTypeDecimalBase::DataTypeDecimalBase(unsigned int, unsigned int) @ 0x0000000013b039e5 5. /build/src/DataTypes/DataTypeDateTime64.cpp:21: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x0000000013b0175c 6. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], unsigned int&, String, 0>(std::allocator const&, unsigned int&, String&&) @ 0x000000000e7d2266 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x0000000012eb038f 8. /build/src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012eb0115 9. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 10. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 11. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:09:02.835353 [ 5121 ] {} TCPHandler: Code: 69. DB::Exception: Scale 100 is out of bounds (max scale: 18): In scope SELECT toDateTime64('2019-09-16 19:20:11.234', 100). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000009fb386b 4. /build/src/DataTypes/DataTypeDecimalBase.h:77: DB::DataTypeDecimalBase::DataTypeDecimalBase(unsigned int, unsigned int) @ 0x0000000013b039e5 5. /build/src/DataTypes/DataTypeDateTime64.cpp:21: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x0000000013b0175c 6. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], unsigned int&, String, 0>(std::allocator const&, unsigned int&, String&&) @ 0x000000000e7d2266 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x0000000012eb038f 8. /build/src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012eb0115 9. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 10. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 11. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:09:03.035950 [ 6614 ] {b031be8b-8808-449b-98c8-4e2a2430a638} executeQuery: Code: 60. DB::Exception: Table test_qm5wpv27.src does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59764) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src update A = 6 where 1 settings mutations_sync=2), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013cf9b5f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144148c9 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001441ace8 7. /build/src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x0000000013cd7e42 8. /build/src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013cd7a7f 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fbcf4 10. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:09:03.099399 [ 6614 ] {} TCPHandler: Code: 60. DB::Exception: Table test_qm5wpv27.src does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013cf9b5f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144148c9 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001441ace8 7. /build/src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x0000000013cd7e42 8. /build/src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013cd7a7f 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fbcf4 10. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:09:03.216129 [ 5121 ] {82b39c84-a519-43dc-8b14-9e9a481275c6} executeQuery: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDateTime64'. Expected: const Integer, got: UInt64: In scope SELECT toDateTime64(CAST([['CLb5Ph ']], 'String'), uniqHLL12('2Gs1V', 752)). (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59694) (comment: 00921_datetime64_basic.sql) (query 8, line 10) (in query: SELECT toDateTime64(CAST([['CLb5Ph ']], 'String'), uniqHLL12('2Gs1V', 752));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/FunctionsConversion.h:2234: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x0000000012eb031d 7. /build/src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012eb0115 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 9. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 25. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 26. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 31. ? @ 0x00007f7210eb6ac3 2025.07.13 02:09:03.288418 [ 5121 ] {} TCPHandler: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDateTime64'. Expected: const Integer, got: UInt64: In scope SELECT toDateTime64(CAST([['CLb5Ph ']], 'String'), uniqHLL12('2Gs1V', 752)). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/FunctionsConversion.h:2234: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x0000000012eb031d 7. /build/src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012eb0115 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 9. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 25. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 26. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 31. ? @ 0x00007f7210eb6ac3 2025.07.13 02:09:03.717697 [ 5121 ] {2bb29ad1-15fc-4eb1-b533-a6e7373396f3} executeQuery: Code: 36. DB::Exception: Cannot load time zone qqq: In scope SELECT toDateTime64('2019-09-16 19:20:11.234', 3, 'qqq'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59694) (comment: 00921_datetime64_basic.sql) (query 9, line 11) (in query: SELECT toDateTime64('2019-09-16 19:20:11.234', 3, 'qqq');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x000000000faae8c8 5. /build/src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x000000000faaaf5e 6. /build/src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x0000000013b01446 7. /build/src/DataTypes/DataTypeDateTime64.cpp:22: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x0000000013b01768 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], unsigned int&, String, 0>(std::allocator const&, unsigned int&, String&&) @ 0x000000000e7d2266 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x0000000012eb038f 10. /build/src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012eb0115 11. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 12. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 13. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 28. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 29. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 2025.07.13 02:09:03.726350 [ 5121 ] {} TCPHandler: Code: 36. DB::Exception: Cannot load time zone qqq: In scope SELECT toDateTime64('2019-09-16 19:20:11.234', 3, 'qqq'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x000000000faae8c8 5. /build/src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x000000000faaaf5e 6. /build/src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x0000000013b01446 7. /build/src/DataTypes/DataTypeDateTime64.cpp:22: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x0000000013b01768 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], unsigned int&, String, 0>(std::allocator const&, unsigned int&, String&&) @ 0x000000000e7d2266 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x0000000012eb038f 10. /build/src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012eb0115 11. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 12. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 13. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 28. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 29. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 2025.07.13 02:09:03.750081 [ 6614 ] {b5158e27-efd5-4a65-b67d-6acea9ef01e6} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'src' in scope SELECT throwIf(A != 6) FROM src. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59798) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: select throwIf(A != 6) from src format Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f633d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:09:03.785764 [ 6614 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'src' in scope SELECT throwIf(A != 6) FROM src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f633d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:09:04.281187 [ 5121 ] {ce58d5e1-252a-43d8-952b-9ca73d5be8b4} executeQuery: Code: 43. DB::Exception: Illegal type UInt64 of 0 argument of function now64. Expected const integer.: In scope SELECT ignore(now64(gccMurmurHash())). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59694) (comment: 00921_datetime64_basic.sql) (query 10, line 13) (in query: SELECT ignore(now64(gccMurmurHash()));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/now64.cpp:144: DB::(anonymous namespace)::Now64OverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000dcf72bc 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 25. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 26. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 31. ? @ 0x00007f7210eb6ac3 2025.07.13 02:09:04.306805 [ 5121 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type UInt64 of 0 argument of function now64. Expected const integer.: In scope SELECT ignore(now64(gccMurmurHash())). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/now64.cpp:144: DB::(anonymous namespace)::Now64OverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000dcf72bc 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 25. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 26. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 31. ? @ 0x00007f7210eb6ac3 2025.07.13 02:09:04.411713 [ 4888 ] {8abae5c9-2e80-4834-ae94-1d013b317d30} executeQuery: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59810) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src detach partition tuple()), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fdd59 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:09:04.425773 [ 4888 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fdd59 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:09:04.506209 [ 5121 ] {8983aba1-80cb-4e64-b747-e5228d22d587} executeQuery: Code: 43. DB::Exception: Illegal type String of 0 argument of function now64. Expected const integer.: In scope SELECT ignore(now64('abcd')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59694) (comment: 00921_datetime64_basic.sql) (query 11, line 14) (in query: SELECT ignore(now64('abcd'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/now64.cpp:144: DB::(anonymous namespace)::Now64OverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000dcf72bc 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 25. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 26. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 31. ? @ 0x00007f7210eb6ac3 2025.07.13 02:09:04.537562 [ 5121 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of 0 argument of function now64. Expected const integer.: In scope SELECT ignore(now64('abcd')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/now64.cpp:144: DB::(anonymous namespace)::Now64OverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000dcf72bc 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 25. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 26. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 31. ? @ 0x00007f7210eb6ac3 2025.07.13 02:09:04.739950 [ 5121 ] {c2d960f4-6054-44c6-a8fb-6c9dbe5ab084} executeQuery: Code: 43. DB::Exception: Illegal type UInt64 of 0 argument of function now64. Expected const integer.: In scope SELECT ignore(now64(number)) FROM system.numbers LIMIT 10. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59694) (comment: 00921_datetime64_basic.sql) (query 12, line 15) (in query: SELECT ignore(now64(number)) FROM system.numbers LIMIT 10;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/now64.cpp:144: DB::(anonymous namespace)::Now64OverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000dcf72bc 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 25. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 26. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 31. ? @ 0x00007f7210eb6ac3 2025.07.13 02:09:04.755636 [ 5121 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type UInt64 of 0 argument of function now64. Expected const integer.: In scope SELECT ignore(now64(number)) FROM system.numbers LIMIT 10. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/now64.cpp:144: DB::(anonymous namespace)::Now64OverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000dcf72bc 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 25. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 26. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 31. ? @ 0x00007f7210eb6ac3 2025.07.13 02:09:04.890869 [ 6614 ] {bb615159-c8a0-43b4-b0e4-b762803ac63e} executeQuery: Code: 36. DB::Exception: Log name 'no_such_log_and_never_will_be' does not exist. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59812) (comment: 03356_system_flush_logs_individual.sh) (query 1, line 1) (in query: SYSTEM FLUSH LOGS no_such_log_and_never_will_be -- { serverError BAD_ARGUMENTS }), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Interpreters/SystemLog.cpp:423: DB::SystemLogs::flush(bool, std::vector> const&) @ 0x0000000014a1f9f9 5. /build/src/Interpreters/InterpreterSystemQuery.cpp:796: DB::InterpreterSystemQuery::execute() @ 0x0000000014bd5a4e 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:09:04.909181 [ 6614 ] {} TCPHandler: Code: 36. DB::Exception: Log name 'no_such_log_and_never_will_be' does not exist. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Interpreters/SystemLog.cpp:423: DB::SystemLogs::flush(bool, std::vector> const&) @ 0x0000000014a1f9f9 5. /build/src/Interpreters/InterpreterSystemQuery.cpp:796: DB::InterpreterSystemQuery::execute() @ 0x0000000014bd5a4e 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:09:05.069055 [ 5121 ] {cb5258a5-d215-4e2e-9e0d-9745fc18444a} executeQuery: Code: 36. DB::Exception: Cannot load time zone invalid timezone: In scope SELECT ignore(now64(3, 'invalid timezone')). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59694) (comment: 00921_datetime64_basic.sql) (query 13, line 16) (in query: SELECT ignore(now64(3, 'invalid timezone'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x000000000faae8c8 5. /build/src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x000000000faaaf5e 6. /build/src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x0000000013b01446 7. /build/src/DataTypes/DataTypeDateTime64.cpp:22: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x0000000013b01768 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], unsigned int&, String&, 0>(std::allocator const&, unsigned int&, String&) @ 0x000000000ce984c6 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::Now64OverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000dcf71f2 10. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 11. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 12. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:09:05.110982 [ 5121 ] {} TCPHandler: Code: 36. DB::Exception: Cannot load time zone invalid timezone: In scope SELECT ignore(now64(3, 'invalid timezone')). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x000000000faae8c8 5. /build/src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x000000000faaaf5e 6. /build/src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x0000000013b01446 7. /build/src/DataTypes/DataTypeDateTime64.cpp:22: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x0000000013b01768 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], unsigned int&, String&, 0>(std::allocator const&, unsigned int&, String&) @ 0x000000000ce984c6 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::Now64OverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000dcf71f2 10. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 11. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 12. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:09:05.117480 [ 4888 ] {7315c300-485b-4cf1-b1ad-ad1447d0eb29} executeQuery: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59834) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src attach partition tuple()), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fdd59 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:09:05.157437 [ 4888 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fdd59 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:09:05.467800 [ 4922 ] {171ca969-5ffa-46ca-b340-090124c29a28} executeQuery: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59678) (comment: 00093_union_race_conditions_4.sh) (query 1, line 1) (in query: SELECT 1 % ((number + 500) % 1000) FROM numbers_mt(1000);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000d09b541 5. /build/src/Functions/FunctionBinaryArithmetic.h:2338: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d2bd336 6. /build/src/Functions/FunctionBinaryArithmetic.h:2508: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d2bb988 7. /build/src/Functions/FunctionBinaryArithmetic.h:846: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d2bade7 8. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d2b72e5 9. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d2b586c 10. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d2b4af4 11. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 22. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:09:05.508439 [ 4922 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000d09b541 5. /build/src/Functions/FunctionBinaryArithmetic.h:2338: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d2bd336 6. /build/src/Functions/FunctionBinaryArithmetic.h:2508: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d2bb988 7. /build/src/Functions/FunctionBinaryArithmetic.h:846: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d2bade7 8. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d2b72e5 9. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d2b586c 10. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d2b4af4 11. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 22. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:09:05.595401 [ 5121 ] {aa161977-bf02-48f5-9835-f1c2116f202b} executeQuery: Code: 44. DB::Exception: Illegal column 1111 of time zone argument of function, must be a constant string: In scope SELECT ignore(now64(3, 1111)). (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59694) (comment: 00921_datetime64_basic.sql) (query 14, line 17) (in query: SELECT ignore(now64(3, 1111));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Functions/extractTimeZoneFromFunctionArguments.cpp:26: DB::extractTimeZoneNameFromColumn(DB::IColumn const*, String const&) @ 0x00000000130b689f 5. /build/src/Functions/extractTimeZoneFromFunctionArguments.cpp:40: DB::extractTimeZoneNameFromFunctionArguments(std::vector> const&, unsigned long, unsigned long, bool) @ 0x00000000130b6968 6. /build/src/Functions/now64.cpp:151: DB::(anonymous namespace)::Now64OverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000dcf71aa 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:09:05.642135 [ 5121 ] {} TCPHandler: Code: 44. DB::Exception: Illegal column 1111 of time zone argument of function, must be a constant string: In scope SELECT ignore(now64(3, 1111)). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Functions/extractTimeZoneFromFunctionArguments.cpp:26: DB::extractTimeZoneNameFromColumn(DB::IColumn const*, String const&) @ 0x00000000130b689f 5. /build/src/Functions/extractTimeZoneFromFunctionArguments.cpp:40: DB::extractTimeZoneNameFromFunctionArguments(std::vector> const&, unsigned long, unsigned long, bool) @ 0x00000000130b6968 6. /build/src/Functions/now64.cpp:151: DB::(anonymous namespace)::Now64OverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000dcf71aa 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:09:06.020069 [ 6619 ] {3810b342-d7de-4ca9-ae33-9a9ca452a7df} executeQuery: Code: 8. DB::Exception: Cannot find column `tuple(col_a, type)` in source stream, there are only columns: [__table1.id, tuple(replaceAll(__table1.data, 'a'_String, 'e'_String), __table1.type), tuple(replaceAll(__table1.data, 'a'_String, 'e'_String), __table1.type)]. (THERE_IS_NO_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59750) (comment: 03240_insert_select_named_tuple.sql) (query 8, line 11) (in query: INSERT INTO dst (id, a, b) SELECT id, tuple(replaceAll(data, 'a', 'e') AS col_a, type) AS a, tuple(replaceAll(data, 'a', 'e') AS col_b, type) AS b FROM src;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Interpreters/ActionsDAG.cpp:1588: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000013ec8cbe 5. /build/src/Processors/QueryPlan/ConvertingActions.cpp:20: DB::addConvertingActions(DB::QueryPlan&, DB::Block const&, bool) @ 0x0000000016cdd8ad 6. /build/src/Processors/QueryPlan/ParallelReplicasLocalPlan.cpp:105: DB::createLocalPlanForParallelReplicas(std::shared_ptr const&, DB::Block const&, std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr, std::unique_ptr>, unsigned long) @ 0x0000000016d235c9 7. /build/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>) @ 0x00000000157ccea8 8. /build/src/Interpreters/ClusterProxy/executeQuery.cpp:721: 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>) @ 0x00000000157cf22e 9. /build/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) @ 0x00000000148b73b9 10. /build/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&) @ 0x00000000148ad029 11. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 12. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:267: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892f39 14. /build/src/Interpreters/InterpreterInsertQuery.cpp:579: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001484e8a5 15. /build/src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001485221d 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:09:06.057321 [ 6619 ] {} TCPHandler: Code: 8. DB::Exception: Cannot find column `tuple(col_a, type)` in source stream, there are only columns: [__table1.id, tuple(replaceAll(__table1.data, 'a'_String, 'e'_String), __table1.type), tuple(replaceAll(__table1.data, 'a'_String, 'e'_String), __table1.type)]. (THERE_IS_NO_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Interpreters/ActionsDAG.cpp:1588: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000013ec8cbe 5. /build/src/Processors/QueryPlan/ConvertingActions.cpp:20: DB::addConvertingActions(DB::QueryPlan&, DB::Block const&, bool) @ 0x0000000016cdd8ad 6. /build/src/Processors/QueryPlan/ParallelReplicasLocalPlan.cpp:105: DB::createLocalPlanForParallelReplicas(std::shared_ptr const&, DB::Block const&, std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr, std::unique_ptr>, unsigned long) @ 0x0000000016d235c9 7. /build/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>) @ 0x00000000157ccea8 8. /build/src/Interpreters/ClusterProxy/executeQuery.cpp:721: 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>) @ 0x00000000157cf22e 9. /build/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) @ 0x00000000148b73b9 10. /build/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&) @ 0x00000000148ad029 11. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 12. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:267: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892f39 14. /build/src/Interpreters/InterpreterInsertQuery.cpp:579: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001484e8a5 15. /build/src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001485221d 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:09:06.138562 [ 16763 ] {b3762192-5113-441d-91bb-be5ef3a20de9} executeQuery: Code: 60. DB::Exception: Table test_qm5wpv27.src does not exist. Maybe you meant test_15.src?. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59836) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src update A = 7 where 1 settings mutations_sync=2), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x000000000a04526b 4. /build/src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013cf9caa 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144148c9 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001441ace8 7. /build/src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x0000000013cd7e42 8. /build/src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013cd7a7f 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fbcf4 10. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:09:06.259756 [ 16763 ] {} TCPHandler: Code: 60. DB::Exception: Table test_qm5wpv27.src does not exist. Maybe you meant test_15.src?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x000000000a04526b 4. /build/src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013cf9caa 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144148c9 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001441ace8 7. /build/src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x0000000013cd7e42 8. /build/src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013cd7a7f 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fbcf4 10. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:09:06.718529 [ 4930 ] {1b3216dc-a951-4146-851f-74aba190be02} 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]:59780) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.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&) @ 0x0000000013b5c099 4. /build/src/IO/readDecimalText.h:163: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x0000000013b5ab0d 5. /build/src/DataTypes/Serializations/SerializationDecimal.cpp:46: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x0000000013bb734d 6. /build/src/Functions/FunctionsConversion.h:1014: 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) @ 0x0000000012de6101 7. /build/src/Functions/FunctionsConversion.h:1580: bool std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(T const&)::operator()>>>(T const&) const @ 0x0000000012dd4b64 8. /build/src/Core/callOnTypeIndex.h:280: std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x0000000012dd29ec 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000012dd27ac 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012cc745b 11. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fc534a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 15. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f75b 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 31. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 2025.07.13 02:09:06.740901 [ 4930 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.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&) @ 0x0000000013b5c099 4. /build/src/IO/readDecimalText.h:163: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x0000000013b5ab0d 5. /build/src/DataTypes/Serializations/SerializationDecimal.cpp:46: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x0000000013bb734d 6. /build/src/Functions/FunctionsConversion.h:1014: 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) @ 0x0000000012de6101 7. /build/src/Functions/FunctionsConversion.h:1580: bool std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(T const&)::operator()>>>(T const&) const @ 0x0000000012dd4b64 8. /build/src/Core/callOnTypeIndex.h:280: std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x0000000012dd29ec 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000012dd27ac 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012cc745b 11. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fc534a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 15. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f75b 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 31. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 2025.07.13 02:09:06.753495 [ 6619 ] {a4640992-5e8a-4532-8781-c9a6598da623} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'src' in scope SELECT throwIf(A != 7) FROM src. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59854) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: select throwIf(A != 7) from src format Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f633d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:09:06.797641 [ 6619 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'src' in scope SELECT throwIf(A != 7) FROM src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f633d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:09:07.386548 [ 6619 ] {d807f822-c552-44e2-b626-7816aa0e461e} executeQuery: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59862) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src detach partition tuple()), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fdd59 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:09:07.420623 [ 6619 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fdd59 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:09:08.279928 [ 6619 ] {fc1d7308-f50b-444e-b508-0e4fb8acc8d3} executeQuery: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59878) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src attach partition tuple()), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fdd59 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:09:08.310649 [ 6619 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fdd59 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:09:09.032368 [ 6619 ] {733cf247-aa36-41d0-b2fc-f2b3b1947d67} executeQuery: Code: 60. DB::Exception: Table test_qm5wpv27.src does not exist. Maybe you meant test_15.src?. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59902) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src update A = 8 where 1 settings mutations_sync=2), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x000000000a04526b 4. /build/src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013cf9caa 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144148c9 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001441ace8 7. /build/src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x0000000013cd7e42 8. /build/src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013cd7a7f 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fbcf4 10. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:09:09.081337 [ 6619 ] {} TCPHandler: Code: 60. DB::Exception: Table test_qm5wpv27.src does not exist. Maybe you meant test_15.src?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x000000000a04526b 4. /build/src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013cf9caa 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144148c9 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001441ace8 7. /build/src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x0000000013cd7e42 8. /build/src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013cd7a7f 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fbcf4 10. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:09:09.723014 [ 5018 ] {c14494a7-3dd7-4fa3-acc0-fa9e1d8a06f9} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'src' in scope SELECT throwIf(A != 8) FROM src. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59984) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: select throwIf(A != 8) from src format Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f633d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:09:09.784141 [ 5018 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'src' in scope SELECT throwIf(A != 8) FROM src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f633d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:09:10.421074 [ 6168 ] {4c496a16-a458-4f06-abf9-90a11a7cdb6c} executeQuery: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60020) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src detach partition tuple()), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fdd59 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:09:10.464868 [ 6168 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fdd59 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:09:10.627617 [ 5121 ] {9ad94027-5393-4451-85cb-f24f030bcc02} 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]:60010) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000a9d88ab 4. /build/src/AggregateFunctions/AggregateFunctionGroupArray.cpp:404: DB::(anonymous namespace)::GroupArrayNodeBase::read(DB::ReadBuffer&, DB::Arena*) @ 0x000000001009d186 5. /build/src/AggregateFunctions/AggregateFunctionGroupArray.cpp:689: DB::(anonymous namespace)::GroupArrayGeneralImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000100c0f3d 6. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000013ba5e3e 7. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:192: DB::SerializationAggregateFunction::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013ba6448 8. /build/src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000013bf4acb 9. /build/src/Processors/Formats/Impl/CSVRowInputFormat.cpp:394: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x0000000016999ac5 10. /build/src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001696b8fc 11. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016940972 12. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 13. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 14. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 18. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 19. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000168e1018 20. /build/src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000001175705f 21. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000130d4903 22. /build/src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000143537f2 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3da49 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 27. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 28. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 2025.07.13 02:09:10.665844 [ 5121 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000a9d88ab 4. /build/src/AggregateFunctions/AggregateFunctionGroupArray.cpp:404: DB::(anonymous namespace)::GroupArrayNodeBase::read(DB::ReadBuffer&, DB::Arena*) @ 0x000000001009d186 5. /build/src/AggregateFunctions/AggregateFunctionGroupArray.cpp:689: DB::(anonymous namespace)::GroupArrayGeneralImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000100c0f3d 6. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000013ba5e3e 7. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:192: DB::SerializationAggregateFunction::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013ba6448 8. /build/src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000013bf4acb 9. /build/src/Processors/Formats/Impl/CSVRowInputFormat.cpp:394: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x0000000016999ac5 10. /build/src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001696b8fc 11. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016940972 12. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 13. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 14. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 18. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 19. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000168e1018 20. /build/src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000001175705f 21. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000130d4903 22. /build/src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000143537f2 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3da49 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 27. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 28. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 2025.07.13 02:09:11.063198 [ 5121 ] {909e6c48-79a5-490d-8f5b-9d641c3aa271} executeQuery: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60036) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src attach partition tuple()), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fdd59 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:09:11.136096 [ 5121 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fdd59 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:09:11.941452 [ 6532 ] {8e382f34-9184-4ecf-99dd-6e39ba5513c3} executeQuery: Code: 60. DB::Exception: Table test_qm5wpv27.src does not exist. Maybe you meant test_15.src?. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60058) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src update A = 9 where 1 settings mutations_sync=2), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x000000000a04526b 4. /build/src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013cf9caa 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144148c9 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001441ace8 7. /build/src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x0000000013cd7e42 8. /build/src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013cd7a7f 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fbcf4 10. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:09:11.989142 [ 6532 ] {} TCPHandler: Code: 60. DB::Exception: Table test_qm5wpv27.src does not exist. Maybe you meant test_15.src?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x000000000a04526b 4. /build/src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013cf9caa 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144148c9 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001441ace8 7. /build/src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x0000000013cd7e42 8. /build/src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013cd7a7f 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fbcf4 10. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:09:12.842450 [ 6532 ] {7e2d9f53-d744-4406-a6b3-e78a29f31140} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'src' in scope SELECT throwIf(A != 9) FROM src. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60088) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: select throwIf(A != 9) from src format Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f633d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:09:12.882557 [ 6532 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'src' in scope SELECT throwIf(A != 9) FROM src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f633d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:09:13.555051 [ 4922 ] {d2d5dbf4-10f4-4d0f-9ed5-6174982c2421} executeQuery: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60142) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src detach partition tuple()), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fdd59 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:09:13.609490 [ 4922 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fdd59 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:09:13.923635 [ 6614 ] {785a2582-23df-40ef-afed-0ff61aa7a2d9} executeQuery: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:59838) (comment: 00093_union_race_conditions_4.sh) (query 1, line 1) (in query: SELECT 1 % ((number + 500) % 1000) FROM numbers_mt(1000);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000d09b541 5. /build/src/Functions/FunctionBinaryArithmetic.h:2338: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d2bd336 6. /build/src/Functions/FunctionBinaryArithmetic.h:2508: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d2bb988 7. /build/src/Functions/FunctionBinaryArithmetic.h:846: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d2bade7 8. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d2b72e5 9. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d2b586c 10. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d2b4af4 11. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 22. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:09:13.965920 [ 6614 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000d09b541 5. /build/src/Functions/FunctionBinaryArithmetic.h:2338: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d2bd336 6. /build/src/Functions/FunctionBinaryArithmetic.h:2508: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d2bb988 7. /build/src/Functions/FunctionBinaryArithmetic.h:846: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d2bade7 8. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d2b72e5 9. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d2b586c 10. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d2b4af4 11. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 22. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:09:14.212024 [ 4922 ] {37aa297a-15a1-4d54-9f8b-e2fc3a99c1fe} executeQuery: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60152) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src attach partition tuple()), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fdd59 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:09:14.268565 [ 4922 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fdd59 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:09:14.993539 [ 4922 ] {18370893-77a3-4c7a-8b29-3eea8da2062f} executeQuery: Code: 60. DB::Exception: Table test_qm5wpv27.src does not exist. Maybe you meant test_15.src?. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60182) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src update A = 10 where 1 settings mutations_sync=2), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x000000000a04526b 4. /build/src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013cf9caa 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144148c9 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001441ace8 7. /build/src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x0000000013cd7e42 8. /build/src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013cd7a7f 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fbcf4 10. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:09:15.056665 [ 4922 ] {} TCPHandler: Code: 60. DB::Exception: Table test_qm5wpv27.src does not exist. Maybe you meant test_15.src?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x000000000a04526b 4. /build/src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013cf9caa 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144148c9 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001441ace8 7. /build/src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x0000000013cd7e42 8. /build/src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013cd7a7f 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fbcf4 10. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:09:15.597995 [ 16756 ] {bc61a47a-80b6-4862-ba8b-c836a39a6b62} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'src' in scope SELECT throwIf(A != 10) FROM src. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60214) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: select throwIf(A != 10) from src format Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f633d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:09:15.647773 [ 16756 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'src' in scope SELECT throwIf(A != 10) FROM src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f633d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:09:16.367880 [ 16756 ] {1e766898-944b-4f9d-91a7-b92d05a3b17f} executeQuery: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60222) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src detach partition tuple()), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fdd59 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:09:16.469977 [ 16756 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fdd59 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:09:16.828230 [ 6532 ] {916da0e0-529e-4ae0-8bda-91b36583bc7b} 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]:60174) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:09:16.884630 [ 6532 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:09:17.101411 [ 16756 ] {ca4ad053-68c5-4109-a598-61500ff163ea} executeQuery: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60252) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src attach partition tuple()), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fdd59 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:09:17.196691 [ 16756 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fdd59 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:09:17.384024 [ 6619 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000013779f8b 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000137794b8 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778bc3 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678d325 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:09:17.634170 [ 3542 ] {0779ca47-82f0-430d-8dcb-e21e89559048} executeQuery: Code: 36. DB::Exception: Path must be inside user-files path: /var/lib/clickhouse/user_files. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60272) (comment: 02921_database_filesystem_path_check.sql) (query 1, line 1) (in query: create database db_filesystem ENGINE=Filesystem('/etc');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Databases/DatabaseFilesystem.cpp:56: DB::DatabaseFilesystem::DatabaseFilesystem(String const&, String const&, std::shared_ptr) @ 0x0000000013c87a7e 5. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], String const&, String&, std::shared_ptr&, 0>(std::allocator const&, String const&, String&, std::shared_ptr&) @ 0x0000000013c8ad58 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::DatabaseFactory::Arguments const&)>::__call_impl[abi:se190107] (DB::DatabaseFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::DatabaseFactory::Arguments const&) @ 0x0000000013c89e78 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c85a56 8. /build/src/Databases/DatabaseFactory.cpp:111: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x0000000013c854a1 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:341: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014806dae 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:09:17.662534 [ 3542 ] {} TCPHandler: Code: 36. DB::Exception: Path must be inside user-files path: /var/lib/clickhouse/user_files. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Databases/DatabaseFilesystem.cpp:56: DB::DatabaseFilesystem::DatabaseFilesystem(String const&, String const&, std::shared_ptr) @ 0x0000000013c87a7e 5. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], String const&, String&, std::shared_ptr&, 0>(std::allocator const&, String const&, String&, std::shared_ptr&) @ 0x0000000013c8ad58 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::DatabaseFactory::Arguments const&)>::__call_impl[abi:se190107] (DB::DatabaseFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::DatabaseFactory::Arguments const&) @ 0x0000000013c89e78 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c85a56 8. /build/src/Databases/DatabaseFactory.cpp:111: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x0000000013c854a1 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:341: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014806dae 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:09:17.871524 [ 6619 ] {ae7f9061-c41c-4627-b99e-2c199bf5b845} executeQuery: Code: 60. DB::Exception: Table test_qm5wpv27.src does not exist. Maybe you meant test_15.src?. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60284) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src update A = 11 where 1 settings mutations_sync=2), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x000000000a04526b 4. /build/src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013cf9caa 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144148c9 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001441ace8 7. /build/src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x0000000013cd7e42 8. /build/src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013cd7a7f 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fbcf4 10. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:09:17.917459 [ 3542 ] {48b1d188-cc69-4f18-b0a2-9452028bf149} executeQuery: Code: 36. DB::Exception: Path must be inside user-files path: /var/lib/clickhouse/user_files. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60272) (comment: 02921_database_filesystem_path_check.sql) (query 2, line 2) (in query: create database db_filesystem ENGINE=Filesystem('../../../../../../../../etc');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Databases/DatabaseFilesystem.cpp:56: DB::DatabaseFilesystem::DatabaseFilesystem(String const&, String const&, std::shared_ptr) @ 0x0000000013c87a7e 5. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], String const&, String&, std::shared_ptr&, 0>(std::allocator const&, String const&, String&, std::shared_ptr&) @ 0x0000000013c8ad58 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::DatabaseFactory::Arguments const&)>::__call_impl[abi:se190107] (DB::DatabaseFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::DatabaseFactory::Arguments const&) @ 0x0000000013c89e78 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c85a56 8. /build/src/Databases/DatabaseFactory.cpp:111: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x0000000013c854a1 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:341: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014806dae 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:09:17.933762 [ 6619 ] {} TCPHandler: Code: 60. DB::Exception: Table test_qm5wpv27.src does not exist. Maybe you meant test_15.src?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x000000000a04526b 4. /build/src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013cf9caa 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144148c9 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001441ace8 7. /build/src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x0000000013cd7e42 8. /build/src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013cd7a7f 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fbcf4 10. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:09:17.984502 [ 3542 ] {} TCPHandler: Code: 36. DB::Exception: Path must be inside user-files path: /var/lib/clickhouse/user_files. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Databases/DatabaseFilesystem.cpp:56: DB::DatabaseFilesystem::DatabaseFilesystem(String const&, String const&, std::shared_ptr) @ 0x0000000013c87a7e 5. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], String const&, String&, std::shared_ptr&, 0>(std::allocator const&, String const&, String&, std::shared_ptr&) @ 0x0000000013c8ad58 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::DatabaseFactory::Arguments const&)>::__call_impl[abi:se190107] (DB::DatabaseFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::DatabaseFactory::Arguments const&) @ 0x0000000013c89e78 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c85a56 8. /build/src/Databases/DatabaseFactory.cpp:111: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x0000000013c854a1 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:341: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014806dae 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:09:18.563368 [ 3543 ] {22d6032b-4b49-4215-b28c-d42fea10dea4} 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]:52742) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/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 @ 0x0000000014916540 5. /build/src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x000000001491636a 6. /build/src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000014ca12b1 7. /build/src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000016b35885 8. /build/src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x0000000016d03ae4 9. /build/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) @ 0x0000000016d0186d 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, 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&&) @ 0x00000000148cff60 11. /build/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&) @ 0x00000000148bfc49 12. /build/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&) @ 0x00000000148bd384 13. /build/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&) @ 0x00000000148adbec 14. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 15. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 17. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 19. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 20. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 2025.07.13 02:09:18.579801 [ 3543 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/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 @ 0x0000000014916540 5. /build/src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x000000001491636a 6. /build/src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000014ca12b1 7. /build/src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000016b35885 8. /build/src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x0000000016d03ae4 9. /build/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) @ 0x0000000016d0186d 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, 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&&) @ 0x00000000148cff60 11. /build/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&) @ 0x00000000148bfc49 12. /build/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&) @ 0x00000000148bd384 13. /build/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&) @ 0x00000000148adbec 14. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 15. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 17. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 19. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 20. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 2025.07.13 02:09:18.634776 [ 3542 ] {650cee46-4c5d-4a40-8580-96c11bcbb416} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'src' in scope SELECT throwIf(A != 11) FROM src. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60306) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: select throwIf(A != 11) from src format Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f633d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:09:18.703843 [ 3542 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'src' in scope SELECT throwIf(A != 11) FROM src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f633d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:09:19.520226 [ 6612 ] {dc176dd9-da71-4ad7-b796-4d7a83df68e0} executeQuery: Code: 107. DB::ErrnoException: Cannot open file /var/lib/clickhouse/format_schemas/nonexist: , errno: 2, strerror: No such file or directory: The table structure cannot be extracted from a Template format file. You can specify the structure manually. (FILE_DOESNT_EXIST) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60318) (comment: 02318_template_schema_inference_bug.sql) (query 2, line 2) (in query: desc file('data_02318.tsv', 'Template') SETTINGS format_template_row='nonexist', format_template_resultset='nonexist';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String&) @ 0x000000000fb766d5 4. /build/src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String&) @ 0x000000000fb76382 5. /build/src/IO/ReadBufferFromFile.cpp:48: DB::ReadBufferFromFile::ReadBufferFromFile(String const&, unsigned long, int, char*, unsigned long, std::optional, std::shared_ptr) @ 0x000000000fb79cec 6. /build/src/Formats/ParsedTemplateFormatString.cpp:19: DB::ParsedTemplateFormatString::ParsedTemplateFormatString(DB::FormatSchemaInfo const&, std::function (String const&)> const&, bool) @ 0x0000000016ae6fc2 7. /build/src/Processors/Formats/Impl/TemplateRowInputFormat.cpp:562: DB::fillRowFormat(DB::FormatSettings const&, std::function (String const&)>, bool) @ 0x0000000016aecd0c 8. /build/src/Processors/Formats/Impl/TemplateRowInputFormat.cpp:614: String std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*, DB::FormatSettings const&) @ 0x0000000016aed113 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001684bed2 10. /build/src/Formats/ReadSchemaUtils.cpp:578: DB::getKeysForSchemaCache(std::vector> const&, String const&, std::optional const&, std::shared_ptr const&) @ 0x000000001689b3fb 11. /build/src/Formats/ReadSchemaUtils.cpp:562: DB::getKeyForSchemaCache(String const&, String const&, std::optional const&, std::shared_ptr const&) @ 0x000000001689b21b 12. /build/src/Storages/StorageFile.cpp:590: DB::(anonymous namespace)::ReadBufferFromFileIterator::tryGetColumnsFromCache(std::vector> const&) @ 0x0000000015cb85db 13. /build/src/Storages/StorageFile.cpp:473: DB::(anonymous namespace)::ReadBufferFromFileIterator::next() @ 0x0000000015cb6e66 14. /build/src/Formats/ReadSchemaUtils.cpp:152: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x0000000016896ec7 15. /build/src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001689af42 16. /build/src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x0000000015ca6941 17. /build/src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x0000000015ca6f9c 18. /build/src/TableFunctions/TableFunctionFile.cpp:119: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000011721477 19. /build/src/Interpreters/InterpreterDescribeQuery.cpp:159: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000014bfbbf1 20. /build/src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x0000000014bfaf18 21. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:09:19.547542 [ 6612 ] {} TCPHandler: Code: 107. DB::ErrnoException: Cannot open file /var/lib/clickhouse/format_schemas/nonexist: , errno: 2, strerror: No such file or directory: The table structure cannot be extracted from a Template format file. You can specify the structure manually. (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String&) @ 0x000000000fb766d5 4. /build/src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String&) @ 0x000000000fb76382 5. /build/src/IO/ReadBufferFromFile.cpp:48: DB::ReadBufferFromFile::ReadBufferFromFile(String const&, unsigned long, int, char*, unsigned long, std::optional, std::shared_ptr) @ 0x000000000fb79cec 6. /build/src/Formats/ParsedTemplateFormatString.cpp:19: DB::ParsedTemplateFormatString::ParsedTemplateFormatString(DB::FormatSchemaInfo const&, std::function (String const&)> const&, bool) @ 0x0000000016ae6fc2 7. /build/src/Processors/Formats/Impl/TemplateRowInputFormat.cpp:562: DB::fillRowFormat(DB::FormatSettings const&, std::function (String const&)>, bool) @ 0x0000000016aecd0c 8. /build/src/Processors/Formats/Impl/TemplateRowInputFormat.cpp:614: String std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*, DB::FormatSettings const&) @ 0x0000000016aed113 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001684bed2 10. /build/src/Formats/ReadSchemaUtils.cpp:578: DB::getKeysForSchemaCache(std::vector> const&, String const&, std::optional const&, std::shared_ptr const&) @ 0x000000001689b3fb 11. /build/src/Formats/ReadSchemaUtils.cpp:562: DB::getKeyForSchemaCache(String const&, String const&, std::optional const&, std::shared_ptr const&) @ 0x000000001689b21b 12. /build/src/Storages/StorageFile.cpp:590: DB::(anonymous namespace)::ReadBufferFromFileIterator::tryGetColumnsFromCache(std::vector> const&) @ 0x0000000015cb85db 13. /build/src/Storages/StorageFile.cpp:473: DB::(anonymous namespace)::ReadBufferFromFileIterator::next() @ 0x0000000015cb6e66 14. /build/src/Formats/ReadSchemaUtils.cpp:152: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x0000000016896ec7 15. /build/src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001689af42 16. /build/src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x0000000015ca6941 17. /build/src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x0000000015ca6f9c 18. /build/src/TableFunctions/TableFunctionFile.cpp:119: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000011721477 19. /build/src/Interpreters/InterpreterDescribeQuery.cpp:159: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000014bfbbf1 20. /build/src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x0000000014bfaf18 21. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:09:20.901477 [ 5121 ] {b880b2db-4bc3-4b03-b076-fe1c05170ef8} executeQuery: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60158) (comment: 00093_union_race_conditions_4.sh) (query 1, line 1) (in query: SELECT 1 % ((number + 500) % 1000) FROM numbers_mt(1000);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000d09b541 5. /build/src/Functions/FunctionBinaryArithmetic.h:2338: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d2bd336 6. /build/src/Functions/FunctionBinaryArithmetic.h:2508: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d2bb988 7. /build/src/Functions/FunctionBinaryArithmetic.h:846: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d2bade7 8. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d2b72e5 9. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d2b586c 10. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d2b4af4 11. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 22. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:09:20.931066 [ 5121 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000d09b541 5. /build/src/Functions/FunctionBinaryArithmetic.h:2338: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d2bd336 6. /build/src/Functions/FunctionBinaryArithmetic.h:2508: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d2bb988 7. /build/src/Functions/FunctionBinaryArithmetic.h:846: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d2bade7 8. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d2b72e5 9. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d2b586c 10. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d2b4af4 11. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 22. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:09:22.222557 [ 3543 ] {a10b4160-5c73-4b08-8567-659fd7e33ccb} 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]:52742) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/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 @ 0x0000000014916540 5. /build/src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x000000001491636a 6. /build/src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000014ca12b1 7. /build/src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000016b35885 8. /build/src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x0000000016d03ae4 9. /build/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) @ 0x0000000016d0186d 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, 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&&) @ 0x00000000148cff60 11. /build/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&) @ 0x00000000148bfc49 12. /build/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&) @ 0x00000000148bd384 13. /build/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&) @ 0x00000000148adbec 14. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 15. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 17. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 19. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 20. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 2025.07.13 02:09:22.230805 [ 3543 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/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 @ 0x0000000014916540 5. /build/src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x000000001491636a 6. /build/src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000014ca12b1 7. /build/src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000016b35885 8. /build/src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x0000000016d03ae4 9. /build/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) @ 0x0000000016d0186d 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, 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&&) @ 0x00000000148cff60 11. /build/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&) @ 0x00000000148bfc49 12. /build/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&) @ 0x00000000148bd384 13. /build/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&) @ 0x00000000148adbec 14. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 15. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 17. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 19. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 20. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 2025.07.13 02:09:22.469455 [ 3543 ] {94ceb481-e48e-4ea1-950f-5c6ac7995307} 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]:52742) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/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 @ 0x0000000014916540 5. /build/src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000014ca12b1 6. /build/src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000016b35885 7. /build/src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x0000000016d03ae4 8. /build/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) @ 0x0000000016d0186d 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, 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&&) @ 0x00000000148cff60 10. /build/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&) @ 0x00000000148bfc49 11. /build/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&) @ 0x00000000148bd384 12. /build/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&) @ 0x00000000148adbec 13. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 14. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:09:22.498620 [ 3543 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/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 @ 0x0000000014916540 5. /build/src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000014ca12b1 6. /build/src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000016b35885 7. /build/src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x0000000016d03ae4 8. /build/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) @ 0x0000000016d0186d 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, 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&&) @ 0x00000000148cff60 10. /build/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&) @ 0x00000000148bfc49 11. /build/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&) @ 0x00000000148bd384 12. /build/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&) @ 0x00000000148adbec 13. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 14. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:09:22.882399 [ 3543 ] {c89f99ec-5b35-47bc-afaa-8579cfc5ba2e} 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]:52742) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/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 @ 0x0000000014916540 5. /build/src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x000000001491636a 6. /build/src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000014ca12b1 7. /build/src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000016b35885 8. /build/src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x0000000016d03ae4 9. /build/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) @ 0x0000000016d0186d 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, 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&&) @ 0x00000000148cff60 11. /build/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&) @ 0x00000000148bfc49 12. /build/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&) @ 0x00000000148bd384 13. /build/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&) @ 0x00000000148adbec 14. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 15. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 17. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 19. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 20. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 2025.07.13 02:09:22.928222 [ 3543 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/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 @ 0x0000000014916540 5. /build/src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x000000001491636a 6. /build/src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000014ca12b1 7. /build/src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000016b35885 8. /build/src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x0000000016d03ae4 9. /build/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) @ 0x0000000016d0186d 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, 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&&) @ 0x00000000148cff60 11. /build/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&) @ 0x00000000148bfc49 12. /build/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&) @ 0x00000000148bd384 13. /build/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&) @ 0x00000000148adbec 14. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 15. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 17. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 19. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 20. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 2025.07.13 02:09:23.125513 [ 6619 ] {be245bdb-d8da-41a3-8094-23f91194d91c} executeQuery: Code: 452. DB::Exception: Setting max_memory_usage shouldn't be greater than 10000000000. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60314) (comment: 01039_test_setting_parse.sql) (query 17, line 17) (in query: SET max_memory_usage = '1T';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000013779f8b 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000137794b8 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:09:23.171113 [ 6619 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000013779f8b 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000137794b8 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:09:23.272297 [ 3543 ] {8d29d496-d27c-4088-80b4-7c0f66c55c8a} 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]:52742) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/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 @ 0x0000000014916540 5. /build/src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000014ca12b1 6. /build/src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000016b35885 7. /build/src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x0000000016d03ae4 8. /build/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) @ 0x0000000016d0186d 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, 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&&) @ 0x00000000148cff60 10. /build/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&) @ 0x00000000148bfc49 11. /build/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&) @ 0x00000000148bd384 12. /build/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&) @ 0x00000000148adbec 13. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 14. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:09:23.316688 [ 3543 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/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 @ 0x0000000014916540 5. /build/src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000014ca12b1 6. /build/src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000016b35885 7. /build/src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x0000000016d03ae4 8. /build/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) @ 0x0000000016d0186d 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, 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&&) @ 0x00000000148cff60 10. /build/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&) @ 0x00000000148bfc49 11. /build/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&) @ 0x00000000148bd384 12. /build/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&) @ 0x00000000148adbec 13. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 14. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:09:26.890450 [ 3543 ] {6b868f97-b872-4cd2-870d-3c282cf50727} 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]:52742) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000009fbd84b 4. /build/src/Functions/FunctionsLogical.cpp:542: DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000012cb015a 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5148: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f66bff 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:09:26.912844 [ 3543 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000009fbd84b 4. /build/src/Functions/FunctionsLogical.cpp:542: DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000012cb015a 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5148: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f66bff 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:09:27.125805 [ 3543 ] {66fbc135-7761-4b2c-bef5-d94f6a8113b7} 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]:52742) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000009fbd84b 4. /build/src/Functions/FunctionsLogical.cpp:542: DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000012cb015a 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5148: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f66bff 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:09:27.139639 [ 3543 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000009fbd84b 4. /build/src/Functions/FunctionsLogical.cpp:542: DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000012cb015a 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5148: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f66bff 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:09:27.400429 [ 6608 ] {7091d9f4-a130-4d2b-b246-d0e9787aab09} executeQuery: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38342) (comment: 00093_union_race_conditions_4.sh) (query 1, line 1) (in query: SELECT 1 % ((number + 500) % 1000) FROM numbers_mt(1000);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000d09b541 5. /build/src/Functions/FunctionBinaryArithmetic.h:2338: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d2bd336 6. /build/src/Functions/FunctionBinaryArithmetic.h:2508: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d2bb988 7. /build/src/Functions/FunctionBinaryArithmetic.h:846: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d2bade7 8. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d2b72e5 9. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d2b586c 10. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d2b4af4 11. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 22. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:09:27.459716 [ 6608 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000d09b541 5. /build/src/Functions/FunctionBinaryArithmetic.h:2338: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d2bd336 6. /build/src/Functions/FunctionBinaryArithmetic.h:2508: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d2bb988 7. /build/src/Functions/FunctionBinaryArithmetic.h:846: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d2bade7 8. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d2b72e5 9. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d2b586c 10. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d2b4af4 11. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 22. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:09:29.350369 [ 5987 ] {b2dc24ed-c2a2-45ea-9e0b-a453cd281d39} executeQuery: Code: 497. DB::Exception: user_03327_permissions_on_refresh_mv_test_9_1: Not enough privileges. To execute this query, it's necessary to have the grant SYSTEM VIEWS ON test_9.mv_test_03327. (ACCESS_DENIED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38450) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000136a8744 5. /build/src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x00000000136a7203 6. /build/src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x00000000136a6851 7. /build/src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x0000000013679004 8. /build/src/Access/ContextAccess.h:256: void DB::Context::checkAccessImpl(DB::AccessFlags const&, String const&, String const&) const @ 0x0000000014374498 9. /build/src/Interpreters/Context.cpp:1759: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&) const @ 0x000000001434c97d 10. /build/src/Interpreters/InterpreterSystemQuery.cpp:1403: DB::InterpreterSystemQuery::getRefreshTasks() @ 0x0000000014bdada9 11. /build/src/Interpreters/InterpreterSystemQuery.cpp:741: DB::InterpreterSystemQuery::execute() @ 0x0000000014bd4246 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 14. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 15. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 20. ? @ 0x00007f7210eb6ac3 21. ? @ 0x00007f7210f48850 2025.07.13 02:09:29.355640 [ 5987 ] {} TCPHandler: Code: 497. DB::Exception: user_03327_permissions_on_refresh_mv_test_9_1: Not enough privileges. To execute this query, it's necessary to have the grant SYSTEM VIEWS ON test_9.mv_test_03327. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000136a8744 5. /build/src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x00000000136a7203 6. /build/src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x00000000136a6851 7. /build/src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x0000000013679004 8. /build/src/Access/ContextAccess.h:256: void DB::Context::checkAccessImpl(DB::AccessFlags const&, String const&, String const&) const @ 0x0000000014374498 9. /build/src/Interpreters/Context.cpp:1759: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&) const @ 0x000000001434c97d 10. /build/src/Interpreters/InterpreterSystemQuery.cpp:1403: DB::InterpreterSystemQuery::getRefreshTasks() @ 0x0000000014bdada9 11. /build/src/Interpreters/InterpreterSystemQuery.cpp:741: DB::InterpreterSystemQuery::execute() @ 0x0000000014bd4246 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 14. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 15. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 20. ? @ 0x00007f7210eb6ac3 21. ? @ 0x00007f7210f48850 2025.07.13 02:09:29.692278 [ 5987 ] {0cd18699-1eb6-4ab1-ba19-522914c611a0} executeQuery: Code: 497. DB::Exception: user_03327_permissions_on_refresh_mv_test_9_1: Not enough privileges. To execute this query, it's necessary to have the grant SYSTEM VIEWS ON test_9.mv_test_03327. (ACCESS_DENIED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38450) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000136a8744 5. /build/src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x00000000136a7203 6. /build/src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x00000000136a6851 7. /build/src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x0000000013679004 8. /build/src/Access/ContextAccess.h:256: DB::InterpreterSystemQuery::startStopAction(unsigned long, bool) @ 0x0000000014bd2550 9. /build/src/Interpreters/InterpreterSystemQuery.cpp:0: DB::InterpreterSystemQuery::execute() @ 0x0000000014bd5fe6 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:09:29.729513 [ 5987 ] {} TCPHandler: Code: 497. DB::Exception: user_03327_permissions_on_refresh_mv_test_9_1: Not enough privileges. To execute this query, it's necessary to have the grant SYSTEM VIEWS ON test_9.mv_test_03327. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000136a8744 5. /build/src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x00000000136a7203 6. /build/src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x00000000136a6851 7. /build/src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x0000000013679004 8. /build/src/Access/ContextAccess.h:256: DB::InterpreterSystemQuery::startStopAction(unsigned long, bool) @ 0x0000000014bd2550 9. /build/src/Interpreters/InterpreterSystemQuery.cpp:0: DB::InterpreterSystemQuery::execute() @ 0x0000000014bd5fe6 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:09:30.354759 [ 5018 ] {06f5fb0e-de04-4810-8750-9a8d725e3cdb} 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]:38426) (comment: 00564_versioned_collapsing_merge_tree.sql) (query 10, line 13) (in query: optimize table mult_tab;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000000fb2dc4b 4. /build/src/Common/MemoryTracker.cpp:196: MemoryTracker::injectFault() const @ 0x000000000fb2b6cd 5. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:153: DB::MergePlainMergeTreeTask::finish() @ 0x0000000016593639 6. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:72: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000016592af2 7. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x0000000016564e9a 8. /build/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) @ 0x000000001656b9cc 9. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014bf58ce 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:09:30.413799 [ 5018 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000000fb2dc4b 4. /build/src/Common/MemoryTracker.cpp:196: MemoryTracker::injectFault() const @ 0x000000000fb2b6cd 5. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:153: DB::MergePlainMergeTreeTask::finish() @ 0x0000000016593639 6. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:72: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000016592af2 7. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x0000000016564e9a 8. /build/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) @ 0x000000001656b9cc 9. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014bf58ce 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:09:30.580650 [ 5987 ] {0bc0f5b0-7053-4b77-b0b8-69156ff72b6f} executeQuery: Code: 497. DB::Exception: user_03327_permissions_on_refresh_mv_test_9_1: Not enough privileges. To execute this query, it's necessary to have the grant SYSTEM VIEWS ON test_9.mv_test_03327. (ACCESS_DENIED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38450) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000136a8744 5. /build/src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x00000000136a7203 6. /build/src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x00000000136a6851 7. /build/src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x0000000013679004 8. /build/src/Access/ContextAccess.h:256: void DB::Context::checkAccessImpl(DB::AccessFlags const&, String const&, String const&) const @ 0x0000000014374498 9. /build/src/Interpreters/Context.cpp:1759: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&) const @ 0x000000001434c97d 10. /build/src/Interpreters/InterpreterSystemQuery.cpp:1403: DB::InterpreterSystemQuery::getRefreshTasks() @ 0x0000000014bdada9 11. /build/src/Interpreters/InterpreterSystemQuery.cpp:745: DB::InterpreterSystemQuery::execute() @ 0x0000000014bd5318 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 14. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 15. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 20. ? @ 0x00007f7210eb6ac3 21. ? @ 0x00007f7210f48850 2025.07.13 02:09:30.605397 [ 5987 ] {} TCPHandler: Code: 497. DB::Exception: user_03327_permissions_on_refresh_mv_test_9_1: Not enough privileges. To execute this query, it's necessary to have the grant SYSTEM VIEWS ON test_9.mv_test_03327. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000136a8744 5. /build/src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x00000000136a7203 6. /build/src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x00000000136a6851 7. /build/src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x0000000013679004 8. /build/src/Access/ContextAccess.h:256: void DB::Context::checkAccessImpl(DB::AccessFlags const&, String const&, String const&) const @ 0x0000000014374498 9. /build/src/Interpreters/Context.cpp:1759: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&) const @ 0x000000001434c97d 10. /build/src/Interpreters/InterpreterSystemQuery.cpp:1403: DB::InterpreterSystemQuery::getRefreshTasks() @ 0x0000000014bdada9 11. /build/src/Interpreters/InterpreterSystemQuery.cpp:745: DB::InterpreterSystemQuery::execute() @ 0x0000000014bd5318 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 14. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 15. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 20. ? @ 0x00007f7210eb6ac3 21. ? @ 0x00007f7210f48850 2025.07.13 02:09:30.853143 [ 5987 ] {92bdc0cd-3faa-4380-8f3d-3ff1e6d29978} executeQuery: Code: 497. DB::Exception: user_03327_permissions_on_refresh_mv_test_9_1: Not enough privileges. To execute this query, it's necessary to have the grant SYSTEM VIEWS ON test_9.mv_test_03327. (ACCESS_DENIED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38450) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000136a8744 5. /build/src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x00000000136a7203 6. /build/src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x00000000136a6851 7. /build/src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x0000000013679004 8. /build/src/Access/ContextAccess.h:256: DB::InterpreterSystemQuery::startStopAction(unsigned long, bool) @ 0x0000000014bd2550 9. /build/src/Interpreters/InterpreterSystemQuery.cpp:0: DB::InterpreterSystemQuery::execute() @ 0x0000000014bd5fe6 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:09:30.890460 [ 5987 ] {} TCPHandler: Code: 497. DB::Exception: user_03327_permissions_on_refresh_mv_test_9_1: Not enough privileges. To execute this query, it's necessary to have the grant SYSTEM VIEWS ON test_9.mv_test_03327. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000136a8744 5. /build/src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x00000000136a7203 6. /build/src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x00000000136a6851 7. /build/src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x0000000013679004 8. /build/src/Access/ContextAccess.h:256: DB::InterpreterSystemQuery::startStopAction(unsigned long, bool) @ 0x0000000014bd2550 9. /build/src/Interpreters/InterpreterSystemQuery.cpp:0: DB::InterpreterSystemQuery::execute() @ 0x0000000014bd5fe6 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:09:31.121461 [ 5987 ] {52a6a9ee-5139-40f4-b2dd-35f345504356} executeQuery: Code: 497. DB::Exception: user_03327_permissions_on_refresh_mv_test_9_1: Not enough privileges. To execute this query, it's necessary to have the grant SYSTEM VIEWS ON test_9.mv_test_03327. (ACCESS_DENIED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38450) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000136a8744 5. /build/src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x00000000136a7203 6. /build/src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x00000000136a6851 7. /build/src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x0000000013679004 8. /build/src/Access/ContextAccess.h:256: void DB::Context::checkAccessImpl(DB::AccessFlags const&, String const&, String const&) const @ 0x0000000014374498 9. /build/src/Interpreters/Context.cpp:1759: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&) const @ 0x000000001434c97d 10. /build/src/Interpreters/InterpreterSystemQuery.cpp:1403: DB::InterpreterSystemQuery::getRefreshTasks() @ 0x0000000014bdada9 11. /build/src/Interpreters/InterpreterSystemQuery.cpp:749: DB::InterpreterSystemQuery::execute() @ 0x0000000014bd3e66 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 14. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 15. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 20. ? @ 0x00007f7210eb6ac3 21. ? @ 0x00007f7210f48850 2025.07.13 02:09:31.131244 [ 5987 ] {} TCPHandler: Code: 497. DB::Exception: user_03327_permissions_on_refresh_mv_test_9_1: Not enough privileges. To execute this query, it's necessary to have the grant SYSTEM VIEWS ON test_9.mv_test_03327. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000136a8744 5. /build/src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x00000000136a7203 6. /build/src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x00000000136a6851 7. /build/src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x0000000013679004 8. /build/src/Access/ContextAccess.h:256: void DB::Context::checkAccessImpl(DB::AccessFlags const&, String const&, String const&) const @ 0x0000000014374498 9. /build/src/Interpreters/Context.cpp:1759: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&) const @ 0x000000001434c97d 10. /build/src/Interpreters/InterpreterSystemQuery.cpp:1403: DB::InterpreterSystemQuery::getRefreshTasks() @ 0x0000000014bdada9 11. /build/src/Interpreters/InterpreterSystemQuery.cpp:749: DB::InterpreterSystemQuery::execute() @ 0x0000000014bd3e66 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 14. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 15. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 20. ? @ 0x00007f7210eb6ac3 21. ? @ 0x00007f7210f48850 2025.07.13 02:09:32.391834 [ 5018 ] {72529928-c29c-4cf8-8b7a-b3db97560c9d} executeQuery: Code: 48. DB::Exception: Cannot rename and modify the same column `value1_string` in a single ALTER query. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36768) (comment: 01281_alter_rename_and_other_renames.sql) (query 4, line 7) (in query: ALTER TABLE rename_table_multiple RENAME COLUMN value1 TO value1_string, MODIFY COLUMN value1_string String;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/AlterCommands.cpp:1486: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015c150a1 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fcff4 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:09:32.415524 [ 5018 ] {} TCPHandler: Code: 48. DB::Exception: Cannot rename and modify the same column `value1_string` in a single ALTER query. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/AlterCommands.cpp:1486: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015c150a1 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fcff4 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:09:32.604623 [ 5018 ] {62cf4192-8b51-41df-b021-77a6a7ba14e2} executeQuery: Code: 48. DB::Exception: Cannot rename and modify the same column `value1` in a single ALTER query. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36768) (comment: 01281_alter_rename_and_other_renames.sql) (query 5, line 8) (in query: ALTER TABLE rename_table_multiple MODIFY COLUMN value1 String, RENAME COLUMN value1 to value1_string;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/AlterCommands.cpp:1683: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015c14fe4 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fcff4 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:09:32.622375 [ 5018 ] {} TCPHandler: Code: 48. DB::Exception: Cannot rename and modify the same column `value1` in a single ALTER query. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/AlterCommands.cpp:1683: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015c14fe4 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fcff4 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:09:32.746625 [ 16758 ] {23ba49a9-340e-4c61-be47-6d9b51258f39} executeQuery: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38448) (comment: 00093_union_race_conditions_4.sh) (query 1, line 1) (in query: SELECT 1 % ((number + 500) % 1000) FROM numbers_mt(1000);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000d09b541 5. /build/src/Functions/FunctionBinaryArithmetic.h:2338: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d2bd336 6. /build/src/Functions/FunctionBinaryArithmetic.h:2508: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d2bb988 7. /build/src/Functions/FunctionBinaryArithmetic.h:846: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d2bade7 8. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d2b72e5 9. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d2b586c 10. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d2b4af4 11. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 22. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:09:32.788940 [ 16758 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000d09b541 5. /build/src/Functions/FunctionBinaryArithmetic.h:2338: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d2bd336 6. /build/src/Functions/FunctionBinaryArithmetic.h:2508: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d2bb988 7. /build/src/Functions/FunctionBinaryArithmetic.h:846: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d2bade7 8. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d2b72e5 9. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d2b586c 10. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d2b4af4 11. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 22. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:09:34.343635 [ 16758 ] {f68fd194-6587-4b80-b057-05bd1ba0c6cd} 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]:36802) (comment: 01911_logical_error_minus.sql) (query 3, line 8) (in query: CREATE TABLE codecTest (`key` UInt64, `name` String, `ref_valueF64` Float64, `ref_valueF32` Float32, `valueF64` Float64 CODEC(Gorilla), `valueF32` Float32 CODEC(Gorilla)) ENGINE = MergeTree ORDER BY key SETTINGS index_granularity = 65394, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 69, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 426354559, compact_parts_max_granules_to_buffer = 80, compact_parts_merge_max_bytes_to_prefetch_part = 19582010, merge_max_block_size = 13376, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 22981, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 15645854, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 26, 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 = 98960, primary_key_compress_block_size = 58696, use_primary_key_cache = false, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000118cbf6e 8. /build/src/Storages/MergeTree/MergeTreeData.cpp:1922: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x0000000016238b3d 9. /build/src/Storages/StorageMergeTree.cpp:161: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000016556df5 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000165568d0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000165531fd 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ca1a22 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001481ee32 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:09:34.395431 [ 16758 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000118cbf6e 8. /build/src/Storages/MergeTree/MergeTreeData.cpp:1922: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x0000000016238b3d 9. /build/src/Storages/StorageMergeTree.cpp:161: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000016556df5 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000165568d0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000165531fd 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ca1a22 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001481ee32 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:09:34.516974 [ 6168 ] {d71b9271-894f-4f3a-a915-c52f0351a073} 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]:60232) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/AggregateFunctions/AggregateFunctionSparkbar.cpp:282: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionSparkbarImpl, std::allocator>>, DB::Array>(String const&, DB::IDataType const&, DB::IDataType const&, std::vector, std::allocator>>, DB::Array) @ 0x0000000011536283 5. /build/src/AggregateFunctions/AggregateFunctionSparkbar.cpp:373: DB::(anonymous namespace)::createAggregateFunctionSparkbar(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000011528e18 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130caa1d 7. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:09:34.597625 [ 6168 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/AggregateFunctions/AggregateFunctionSparkbar.cpp:282: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionSparkbarImpl, std::allocator>>, DB::Array>(String const&, DB::IDataType const&, DB::IDataType const&, std::vector, std::allocator>>, DB::Array) @ 0x0000000011536283 5. /build/src/AggregateFunctions/AggregateFunctionSparkbar.cpp:373: DB::(anonymous namespace)::createAggregateFunctionSparkbar(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000011528e18 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130caa1d 7. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:09:34.712212 [ 6168 ] {5f6078eb-5a7c-4adc-9ffb-6a6ae17e92e3} 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]:60232) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/AggregateFunctions/AggregateFunctionSparkbar.cpp:282: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionSparkbarImpl, std::allocator>>, DB::Array>(String const&, DB::IDataType const&, DB::IDataType const&, std::vector, std::allocator>>, DB::Array) @ 0x0000000011536283 5. /build/src/AggregateFunctions/AggregateFunctionSparkbar.cpp:373: DB::(anonymous namespace)::createAggregateFunctionSparkbar(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000011528e18 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130caa1d 7. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:09:34.732005 [ 6168 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/AggregateFunctions/AggregateFunctionSparkbar.cpp:282: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionSparkbarImpl, std::allocator>>, DB::Array>(String const&, DB::IDataType const&, DB::IDataType const&, std::vector, std::allocator>>, DB::Array) @ 0x0000000011536283 5. /build/src/AggregateFunctions/AggregateFunctionSparkbar.cpp:373: DB::(anonymous namespace)::createAggregateFunctionSparkbar(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000011528e18 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130caa1d 7. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:09:34.912098 [ 6168 ] {ee05fbcd-ec60-40fa-b399-ee82dacb5c99} 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]:60232) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/AggregateFunctions/AggregateFunctionSparkbar.cpp:282: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionSparkbarImpl, std::allocator>>, DB::Array>(String const&, DB::IDataType const&, DB::IDataType const&, std::vector, std::allocator>>, DB::Array) @ 0x0000000011536283 5. /build/src/AggregateFunctions/AggregateFunctionSparkbar.cpp:373: DB::(anonymous namespace)::createAggregateFunctionSparkbar(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000011528e18 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130caa1d 7. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:09:34.935850 [ 6168 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/AggregateFunctions/AggregateFunctionSparkbar.cpp:282: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionSparkbarImpl, std::allocator>>, DB::Array>(String const&, DB::IDataType const&, DB::IDataType const&, std::vector, std::allocator>>, DB::Array) @ 0x0000000011536283 5. /build/src/AggregateFunctions/AggregateFunctionSparkbar.cpp:373: DB::(anonymous namespace)::createAggregateFunctionSparkbar(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000011528e18 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130caa1d 7. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:09:35.364404 [ 6168 ] {1da941a4-6e64-4460-8882-25986c23fe75} 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]:60232) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/AggregateFunctions/AggregateFunctionSparkbar.cpp:285: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionSparkbarImpl, std::allocator>>, DB::Array>(String const&, DB::IDataType const&, DB::IDataType const&, std::vector, std::allocator>>, DB::Array) @ 0x0000000011530e80 5. /build/src/AggregateFunctions/AggregateFunctionSparkbar.cpp:373: DB::(anonymous namespace)::createAggregateFunctionSparkbar(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000011528e18 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130caa1d 7. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:09:35.386196 [ 6168 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/AggregateFunctions/AggregateFunctionSparkbar.cpp:285: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionSparkbarImpl, std::allocator>>, DB::Array>(String const&, DB::IDataType const&, DB::IDataType const&, std::vector, std::allocator>>, DB::Array) @ 0x0000000011530e80 5. /build/src/AggregateFunctions/AggregateFunctionSparkbar.cpp:373: DB::(anonymous namespace)::createAggregateFunctionSparkbar(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000011528e18 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130caa1d 7. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:09:35.887837 [ 6168 ] {1c770d9d-d2c9-4688-a445-8ff042c319ac} 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]:60232) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/AggregateFunctions/AggregateFunctionSparkbar.cpp:369: DB::(anonymous namespace)::createAggregateFunctionSparkbar(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000115290c2 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130caa1d 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:09:35.934781 [ 6168 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/AggregateFunctions/AggregateFunctionSparkbar.cpp:369: DB::(anonymous namespace)::createAggregateFunctionSparkbar(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000115290c2 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130caa1d 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:09:36.149722 [ 6168 ] {33a3ecd5-c9a1-4b9b-823e-a808f16066f1} 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]:60232) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/AggregateFunctions/AggregateFunctionSparkbar.cpp:369: DB::(anonymous namespace)::createAggregateFunctionSparkbar(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000115290c2 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130caa1d 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:09:36.162769 [ 6168 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/AggregateFunctions/AggregateFunctionSparkbar.cpp:369: DB::(anonymous namespace)::createAggregateFunctionSparkbar(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000115290c2 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130caa1d 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:09:36.404144 [ 6168 ] {cd3da072-8823-4254-9acd-21a37fc778ee} 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]:60232) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/AggregateFunctions/AggregateFunctionSparkbar.cpp:339: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionSparkbarImpl, std::allocator>>, DB::Array>(String const&, DB::IDataType const&, DB::IDataType const&, std::vector, std::allocator>>, DB::Array) @ 0x00000000115356fc 5. /build/src/AggregateFunctions/AggregateFunctionSparkbar.cpp:373: DB::(anonymous namespace)::createAggregateFunctionSparkbar(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000011528e18 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130caa1d 7. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:09:36.415526 [ 6168 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/AggregateFunctions/AggregateFunctionSparkbar.cpp:339: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionSparkbarImpl, std::allocator>>, DB::Array>(String const&, DB::IDataType const&, DB::IDataType const&, std::vector, std::allocator>>, DB::Array) @ 0x00000000115356fc 5. /build/src/AggregateFunctions/AggregateFunctionSparkbar.cpp:373: DB::(anonymous namespace)::createAggregateFunctionSparkbar(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000011528e18 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130caa1d 7. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:09:36.692612 [ 6168 ] {67a91760-247c-48c4-8fcc-53dcd70fc04a} 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]:60232) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, unsigned long&&) @ 0x000000000a8cbe8b 4. /build/src/AggregateFunctions/AggregateFunctionSparkbar.cpp:361: DB::(anonymous namespace)::createAggregateFunctionSparkbar(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000011529041 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130caa1d 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:09:36.736350 [ 6168 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, unsigned long&&) @ 0x000000000a8cbe8b 4. /build/src/AggregateFunctions/AggregateFunctionSparkbar.cpp:361: DB::(anonymous namespace)::createAggregateFunctionSparkbar(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000011529041 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130caa1d 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:09:36.989760 [ 6168 ] {e0d7ae69-a7aa-4b20-8f95-f2ebeff7709b} 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]:60232) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, unsigned long&&) @ 0x000000000a8cbe8b 4. /build/src/AggregateFunctions/AggregateFunctionSparkbar.cpp:361: DB::(anonymous namespace)::createAggregateFunctionSparkbar(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000011529041 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130caa1d 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:09:36.996275 [ 6168 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, unsigned long&&) @ 0x000000000a8cbe8b 4. /build/src/AggregateFunctions/AggregateFunctionSparkbar.cpp:361: DB::(anonymous namespace)::createAggregateFunctionSparkbar(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000011529041 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130caa1d 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:09:38.841016 [ 4922 ] {756c589d-d9f3-4238-95bb-dcc867edfe72} executeQuery: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36810) (comment: 00093_union_race_conditions_4.sh) (query 1, line 1) (in query: SELECT 1 % ((number + 500) % 1000) FROM numbers_mt(1000);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000d09b541 5. /build/src/Functions/FunctionBinaryArithmetic.h:2338: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d2bd336 6. /build/src/Functions/FunctionBinaryArithmetic.h:2508: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d2bb988 7. /build/src/Functions/FunctionBinaryArithmetic.h:846: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d2bade7 8. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d2b72e5 9. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d2b586c 10. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d2b4af4 11. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 22. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:09:38.877674 [ 4922 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000d09b541 5. /build/src/Functions/FunctionBinaryArithmetic.h:2338: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d2bd336 6. /build/src/Functions/FunctionBinaryArithmetic.h:2508: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d2bb988 7. /build/src/Functions/FunctionBinaryArithmetic.h:846: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d2bade7 8. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d2b72e5 9. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d2b586c 10. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d2b4af4 11. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 22. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:09:39.772645 [ 5018 ] {9ce99e73-3351-49c8-8e11-a6abbe0607c8} executeQuery: Code: 48. DB::Exception: Cannot rename and modify the same column `value1_string` in a single ALTER query. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36768) (comment: 01281_alter_rename_and_other_renames.sql) (query 22, line 41) (in query: ALTER TABLE rename_table_multiple_compact RENAME COLUMN value1 TO value1_string, MODIFY COLUMN value1_string String;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/AlterCommands.cpp:1486: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015c150a1 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fcff4 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:09:39.800246 [ 5018 ] {} TCPHandler: Code: 48. DB::Exception: Cannot rename and modify the same column `value1_string` in a single ALTER query. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/AlterCommands.cpp:1486: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015c150a1 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fcff4 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:09:39.913548 [ 5018 ] {9b077066-f6f3-432c-8510-ed227a752214} executeQuery: Code: 48. DB::Exception: Cannot rename and modify the same column `value1` in a single ALTER query. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36768) (comment: 01281_alter_rename_and_other_renames.sql) (query 23, line 42) (in query: ALTER TABLE rename_table_multiple_compact MODIFY COLUMN value1 String, RENAME COLUMN value1 to value1_string;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/AlterCommands.cpp:1683: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015c14fe4 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fcff4 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:09:39.945952 [ 5018 ] {} TCPHandler: Code: 48. DB::Exception: Cannot rename and modify the same column `value1` in a single ALTER query. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/AlterCommands.cpp:1683: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015c14fe4 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fcff4 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:09:43.578954 [ 3543 ] {d96fb914-6146-444c-99a4-ba54b36ca972} 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]:52742) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Interpreters/ActionsDAG.cpp:1282: DB::ActionsDAG::appendInputsForUnusedColumns(DB::Block const&) @ 0x0000000013ec653f 5. /build/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_ @ 0x00000000148beb4f 6. /build/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&) @ 0x00000000148bc373 7. /build/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&) @ 0x00000000148adbec 8. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 9. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:09:43.597930 [ 3543 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Interpreters/ActionsDAG.cpp:1282: DB::ActionsDAG::appendInputsForUnusedColumns(DB::Block const&) @ 0x0000000013ec653f 5. /build/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_ @ 0x00000000148beb4f 6. /build/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&) @ 0x00000000148bc373 7. /build/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&) @ 0x00000000148adbec 8. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 9. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:09:45.764667 [ 6614 ] {331f28ca-f236-45fd-a7d2-b7acb42d7e6b} executeQuery: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38576) (comment: 00093_union_race_conditions_4.sh) (query 1, line 1) (in query: SELECT 1 % ((number + 500) % 1000) FROM numbers_mt(1000);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000d09b541 5. /build/src/Functions/FunctionBinaryArithmetic.h:2338: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d2bd336 6. /build/src/Functions/FunctionBinaryArithmetic.h:2508: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d2bb988 7. /build/src/Functions/FunctionBinaryArithmetic.h:846: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d2bade7 8. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d2b72e5 9. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d2b586c 10. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d2b4af4 11. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 22. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:09:45.878570 [ 6614 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000d09b541 5. /build/src/Functions/FunctionBinaryArithmetic.h:2338: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d2bd336 6. /build/src/Functions/FunctionBinaryArithmetic.h:2508: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d2bb988 7. /build/src/Functions/FunctionBinaryArithmetic.h:846: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d2bade7 8. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d2b72e5 9. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d2b586c 10. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d2b4af4 11. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 22. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:09:47.200829 [ 4930 ] {5b115462-5910-41e7-a970-feed841748c0} executeQuery: Code: 44. DB::Exception: Cannot create table with column '_row_exists' for MergeTree engines because it is reserved for persistent virtual column. (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38696) (comment: 02454_disable_mergetree_with_lightweight_delete_column.sql) (query 2, line 3) (in query: CREATE TABLE t_row_exists (`a` int, `_row_exists` int) ENGINE = MergeTree ORDER BY a SETTINGS index_granularity = 37919, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.07839881628751755, replace_long_file_name_to_hash = true, max_file_name_length = 68, min_bytes_for_full_part_storage = 189861383, compact_parts_max_bytes_to_buffer = 440275306, compact_parts_max_granules_to_buffer = 144, compact_parts_merge_max_bytes_to_prefetch_part = 17406596, merge_max_block_size = 15985, old_parts_lifetime = 36., prefer_fetch_merged_part_size_threshold = 2760464413, 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 = 9937879, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 34, 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 = 27261, primary_key_compress_block_size = 11800, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1048: DB::validateVirtualColumns(DB::IStorage const&) @ 0x00000000148125d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1954: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001481efb5 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 10. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:09:47.235608 [ 4930 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create table with column '_row_exists' for MergeTree engines because it is reserved for persistent virtual column. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1048: DB::validateVirtualColumns(DB::IStorage const&) @ 0x00000000148125d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1954: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001481efb5 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 10. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:09:47.875579 [ 4930 ] {31509c10-e4f9-4ddd-bc51-ca77fe25e1eb} executeQuery: Code: 44. DB::Exception: Cannot add column `_row_exists`: this column name is reserved for persistent virtual column. (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38696) (comment: 02454_disable_mergetree_with_lightweight_delete_column.sql) (query 4, line 6) (in query: alter table t_row_exists add column _row_exists int;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/AlterCommands.cpp:1456: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015c15f1c 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fcff4 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:09:47.912382 [ 4930 ] {} TCPHandler: Code: 44. DB::Exception: Cannot add column `_row_exists`: this column name is reserved for persistent virtual column. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/AlterCommands.cpp:1456: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015c15f1c 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fcff4 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:09:48.231955 [ 4930 ] {e2eeb3f9-74b3-4e3c-a152-a6e6bea775c9} executeQuery: Code: 44. DB::Exception: Cannot rename to `_row_exists`: this column name is reserved for persistent virtual column. (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38696) (comment: 02454_disable_mergetree_with_lightweight_delete_column.sql) (query 5, line 7) (in query: alter table t_row_exists rename column b to _row_exists;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/AlterCommands.cpp:1679: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015c15853 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fcff4 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:09:48.270773 [ 4930 ] {} TCPHandler: Code: 44. DB::Exception: Cannot rename to `_row_exists`: this column name is reserved for persistent virtual column. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/AlterCommands.cpp:1679: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015c15853 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fcff4 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:09:48.569583 [ 4930 ] {a67fabea-f1ec-431b-8aa7-ceb03ff76877} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `_row_exists` to rename. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38696) (comment: 02454_disable_mergetree_with_lightweight_delete_column.sql) (query 6, line 8) (in query: alter table t_row_exists rename column _row_exists to c;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Storages/AlterCommands.cpp:1669: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015c1517c 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fcff4 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:09:48.576783 [ 4930 ] {} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `_row_exists` to rename. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Storages/AlterCommands.cpp:1669: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015c1517c 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fcff4 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:09:48.826360 [ 4930 ] {80381b5d-aaff-419a-bf9c-456cbbf8608a} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `_row_exists` to drop. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38696) (comment: 02454_disable_mergetree_with_lightweight_delete_column.sql) (query 7, line 9) (in query: alter table t_row_exists drop column _row_exists;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015c15c0f 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fcff4 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:09:48.847873 [ 4930 ] {} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `_row_exists` to drop. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015c15c0f 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fcff4 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:09:49.000937 [ 4930 ] {478c0471-8f17-4e02-b5a6-ef7fd92736b5} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `unknown_column` to drop. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38696) (comment: 02454_disable_mergetree_with_lightweight_delete_column.sql) (query 8, line 10) (in query: alter table t_row_exists drop column unknown_column;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015c15c0f 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fcff4 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:09:49.040812 [ 4930 ] {} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `unknown_column` to drop. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015c15c0f 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fcff4 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:09:49.300626 [ 4930 ] {77e860a9-7a6a-4f20-9e2b-23db1fdd2828} executeQuery: Code: 57. DB::Exception: Table test_1.t_row_exists already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38696) (comment: 02454_disable_mergetree_with_lightweight_delete_column.sql) (query 10, line 13) (in query: create table t_row_exists(a int, _row_exists int) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:09:49.342794 [ 4930 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.t_row_exists already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:09:52.698839 [ 5121 ] {dacc958a-b516-48b8-bf14-34bbaf969695} executeQuery: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38692) (comment: 00093_union_race_conditions_4.sh) (query 1, line 1) (in query: SELECT 1 % ((number + 500) % 1000) FROM numbers_mt(1000);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000d09b541 5. /build/src/Functions/FunctionBinaryArithmetic.h:2338: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d2bd336 6. /build/src/Functions/FunctionBinaryArithmetic.h:2508: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d2bb988 7. /build/src/Functions/FunctionBinaryArithmetic.h:846: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d2bade7 8. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d2b72e5 9. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d2b586c 10. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d2b4af4 11. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 22. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:09:52.743271 [ 5121 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000d09b541 5. /build/src/Functions/FunctionBinaryArithmetic.h:2338: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d2bd336 6. /build/src/Functions/FunctionBinaryArithmetic.h:2508: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d2bb988 7. /build/src/Functions/FunctionBinaryArithmetic.h:846: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d2bade7 8. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d2b72e5 9. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d2b586c 10. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d2b4af4 11. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 22. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:09:57.931512 [ 3543 ] {8b2c398e-f6bc-45ff-8d57-a56891f2874a} 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]:52742) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/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 @ 0x0000000014916540 5. /build/src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x000000001491636a 6. /build/src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000014ca12b1 7. /build/src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000016b35885 8. /build/src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x0000000016d03ae4 9. /build/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) @ 0x0000000016d0186d 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, 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&&) @ 0x00000000148cff60 11. /build/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&) @ 0x00000000148bfc49 12. /build/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&) @ 0x00000000148bd384 13. /build/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&) @ 0x00000000148adbec 14. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 15. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 17. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 19. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 20. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 2025.07.13 02:09:57.961085 [ 3543 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/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 @ 0x0000000014916540 5. /build/src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x000000001491636a 6. /build/src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000014ca12b1 7. /build/src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000016b35885 8. /build/src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x0000000016d03ae4 9. /build/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) @ 0x0000000016d0186d 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, 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&&) @ 0x00000000148cff60 11. /build/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&) @ 0x00000000148bfc49 12. /build/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&) @ 0x00000000148bd384 13. /build/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&) @ 0x00000000148adbec 14. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 15. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 17. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 19. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 20. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 2025.07.13 02:09:59.991871 [ 16758 ] {61e30f5d-36e2-4817-958f-ed587121c06c} executeQuery: Code: 1. DB::Exception: Set `store_polygon_key_column` setting in dictionary configuration to true to support reading from PolygonDictionary. (UNSUPPORTED_METHOD) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45984) (comment: 02097_polygon_dictionary_store_key.sql) (query 6, line 21) (in query: SELECT * FROM polygons_test_dictionary_no_option;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Dictionaries/PolygonDictionary.cpp:209: DB::IPolygonDictionary::read(std::vector> const&, unsigned long, unsigned long) const @ 0x0000000011c00348 5. /build/src/Storages/StorageDictionary.cpp:201: DB::StorageDictionary::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000015c78777 6. /build/src/Storages/IStorage.cpp:184: DB::IStorage::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000015c3cfce 7. /build/src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000148b600e 8. /build/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&) @ 0x00000000148ad029 9. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 10. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 12. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 14. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 15. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 20. ? @ 0x00007f7210eb6ac3 21. ? @ 0x00007f7210f48850 2025.07.13 02:10:00.020135 [ 16758 ] {} TCPHandler: Code: 1. DB::Exception: Set `store_polygon_key_column` setting in dictionary configuration to true to support reading from PolygonDictionary. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Dictionaries/PolygonDictionary.cpp:209: DB::IPolygonDictionary::read(std::vector> const&, unsigned long, unsigned long) const @ 0x0000000011c00348 5. /build/src/Storages/StorageDictionary.cpp:201: DB::StorageDictionary::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000015c78777 6. /build/src/Storages/IStorage.cpp:184: DB::IStorage::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000015c3cfce 7. /build/src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000148b600e 8. /build/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&) @ 0x00000000148ad029 9. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 10. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 12. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 14. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 15. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 20. ? @ 0x00007f7210eb6ac3 21. ? @ 0x00007f7210f48850 2025.07.13 02:10:00.741987 [ 3543 ] {28fcca75-bad4-4090-8343-3726854dc7b4} 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]:52742) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/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 @ 0x0000000014916540 5. /build/src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x000000001491636a 6. /build/src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000014ca12b1 7. /build/src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000016b35885 8. /build/src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x0000000016d03ae4 9. /build/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) @ 0x0000000016d0186d 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, 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&&) @ 0x00000000148cff60 11. /build/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&) @ 0x00000000148bfc49 12. /build/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&) @ 0x00000000148bd384 13. /build/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&) @ 0x00000000148adbec 14. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 15. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 17. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 19. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 20. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 2025.07.13 02:10:00.748616 [ 3543 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/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 @ 0x0000000014916540 5. /build/src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x000000001491636a 6. /build/src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000014ca12b1 7. /build/src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000016b35885 8. /build/src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x0000000016d03ae4 9. /build/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) @ 0x0000000016d0186d 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, 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&&) @ 0x00000000148cff60 11. /build/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&) @ 0x00000000148bfc49 12. /build/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&) @ 0x00000000148bd384 13. /build/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&) @ 0x00000000148adbec 14. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 15. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 17. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 19. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 20. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 2025.07.13 02:10:00.886848 [ 3543 ] {373b3aa9-873c-48a5-9bdb-a68da7f9f405} 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]:52742) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/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 @ 0x0000000014916540 5. /build/src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000014ca12b1 6. /build/src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000016b35885 7. /build/src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x0000000016d03ae4 8. /build/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) @ 0x0000000016d0186d 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, 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&&) @ 0x00000000148cff60 10. /build/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&) @ 0x00000000148bfc49 11. /build/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&) @ 0x00000000148bd384 12. /build/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&) @ 0x00000000148adbec 13. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 14. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:10:00.897287 [ 3543 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/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 @ 0x0000000014916540 5. /build/src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000014ca12b1 6. /build/src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000016b35885 7. /build/src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x0000000016d03ae4 8. /build/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) @ 0x0000000016d0186d 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, 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&&) @ 0x00000000148cff60 10. /build/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&) @ 0x00000000148bfc49 11. /build/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&) @ 0x00000000148bd384 12. /build/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&) @ 0x00000000148adbec 13. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 14. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:10:00.981584 [ 12992 ] {20f525e2-34f9-422b-9c1c-93bfa9713be1} ExternalDictionariesLoader: Could not load external dictionary '9a1f5b45-b9af-41a1-bd85-fc671624809c', next update is scheduled at 2025-07-13 02:10:05: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000013af9e0b 4. /build/src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013af97c1 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000016b4227b 6. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 7. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 10. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000168e1018 13. /build/src/Dictionaries/FlatDictionary.cpp:502: DB::FlatDictionary::loadData() @ 0x0000000011a2e94b 14. /build/src/Dictionaries/FlatDictionary.cpp:46: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x0000000011a2e591 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:se190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x0000000011a49862 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012c74f5d 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000147cade4 18. /build/src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000147d6c48 19. /build/src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000147d56dd 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000147d96f4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000147d64cd 5. /build/src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000147d465c 6. /build/src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x00000000147e47a8 7. /build/contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&) @ 0x00000000147e445c 8. /build/src/Interpreters/ExternalLoader.cpp:604: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000147d0b9f 9. /build/src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000147d0e15 10. /build/src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000147cb768 11. /build/src/Functions/FunctionsExternalDictionaries.h:76: DB::FunctionDictHelper::getDictionary(String const&) @ 0x000000000a11476c 12. /build/src/Functions/FunctionsExternalDictionaries.h:426: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a11185e 13. /build/src/Functions/FunctionsExternalDictionaries.h:831: DB::FunctionDictGetImpl, DB::NameDictGetUInt64, (DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a1257a2 14. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 15. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 16. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 17. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 18. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 19. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 20. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 27. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 28. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 32. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 33. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 34. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 35. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 36. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 37. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 38. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 39. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 40. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 41. ? @ 0x00007f7210eb6ac3 42. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:10:00.991427 [ 5987 ] {20f525e2-34f9-422b-9c1c-93bfa9713be1} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: In scope SELECT dictGetUInt64('ordinary_db.dict1', 'second_column', toUInt64(100500)). (TOO_MANY_ROWS_OR_BYTES) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45962) (comment: 01259_dictionary_custom_settings_ddl.sql) (query 8, line 33) (in query: SELECT dictGetUInt64('ordinary_db.dict1', 'second_column', toUInt64(100500));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000013af9e0b 4. /build/src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013af97c1 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000016b4227b 6. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 7. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 10. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000168e1018 13. /build/src/Dictionaries/FlatDictionary.cpp:502: DB::FlatDictionary::loadData() @ 0x0000000011a2e94b 14. /build/src/Dictionaries/FlatDictionary.cpp:46: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x0000000011a2e591 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:se190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x0000000011a49862 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012c74f5d 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000147cade4 18. /build/src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000147d6c48 19. /build/src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000147d56dd 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000147d96f4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:10:00.999454 [ 5987 ] {} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: In scope SELECT dictGetUInt64('ordinary_db.dict1', 'second_column', toUInt64(100500)). (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000013af9e0b 4. /build/src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013af97c1 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000016b4227b 6. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 7. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 10. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000168e1018 13. /build/src/Dictionaries/FlatDictionary.cpp:502: DB::FlatDictionary::loadData() @ 0x0000000011a2e94b 14. /build/src/Dictionaries/FlatDictionary.cpp:46: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x0000000011a2e591 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:se190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x0000000011a49862 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012c74f5d 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000147cade4 18. /build/src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000147d6c48 19. /build/src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000147d56dd 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000147d96f4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000147d64cd 5. /build/src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000147d465c 6. /build/src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x00000000147e47a8 7. /build/contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&) @ 0x00000000147e445c 8. /build/src/Interpreters/ExternalLoader.cpp:604: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000147d0b9f 9. /build/src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000147d0e15 10. /build/src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000147cb768 11. /build/src/Functions/FunctionsExternalDictionaries.h:76: DB::FunctionDictHelper::getDictionary(String const&) @ 0x000000000a11476c 12. /build/src/Functions/FunctionsExternalDictionaries.h:426: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a11185e 13. /build/src/Functions/FunctionsExternalDictionaries.h:831: DB::FunctionDictGetImpl, DB::NameDictGetUInt64, (DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a1257a2 14. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 15. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 16. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 17. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 18. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 19. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 20. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 27. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 28. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 32. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 33. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 34. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 35. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 36. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 37. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 38. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 39. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 40. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 41. ? @ 0x00007f7210eb6ac3 42. ? @ 0x00007f7210f48850 2025.07.13 02:10:01.030660 [ 3543 ] {3824572a-a15b-428b-9c1b-e327a90985db} 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]:52742) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/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 @ 0x0000000014916540 5. /build/src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x000000001491636a 6. /build/src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000014ca12b1 7. /build/src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000016b35885 8. /build/src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x0000000016d03ae4 9. /build/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) @ 0x0000000016d0186d 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, 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&&) @ 0x00000000148cff60 11. /build/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&) @ 0x00000000148bfc49 12. /build/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&) @ 0x00000000148bd384 13. /build/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&) @ 0x00000000148adbec 14. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 15. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 17. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 19. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 20. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 2025.07.13 02:10:01.045063 [ 3543 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/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 @ 0x0000000014916540 5. /build/src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x000000001491636a 6. /build/src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000014ca12b1 7. /build/src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000016b35885 8. /build/src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x0000000016d03ae4 9. /build/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) @ 0x0000000016d0186d 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, 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&&) @ 0x00000000148cff60 11. /build/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&) @ 0x00000000148bfc49 12. /build/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&) @ 0x00000000148bd384 13. /build/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&) @ 0x00000000148adbec 14. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 15. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 17. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 19. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 20. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 2025.07.13 02:10:01.173641 [ 3543 ] {df6b2e2e-db28-4484-8e15-e16d64f91a5c} 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]:52742) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/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 @ 0x0000000014916540 5. /build/src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000014ca12b1 6. /build/src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000016b35885 7. /build/src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x0000000016d03ae4 8. /build/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) @ 0x0000000016d0186d 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, 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&&) @ 0x00000000148cff60 10. /build/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&) @ 0x00000000148bfc49 11. /build/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&) @ 0x00000000148bd384 12. /build/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&) @ 0x00000000148adbec 13. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 14. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:10:01.197897 [ 3543 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/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 @ 0x0000000014916540 5. /build/src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000014ca12b1 6. /build/src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000016b35885 7. /build/src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x0000000016d03ae4 8. /build/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) @ 0x0000000016d0186d 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, 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&&) @ 0x00000000148cff60 10. /build/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&) @ 0x00000000148bfc49 11. /build/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&) @ 0x00000000148bd384 12. /build/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&) @ 0x00000000148adbec 13. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 14. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:10:02.419114 [ 6612 ] {11bccf11-3505-4879-9031-20d4846d5edc} executeQuery: Code: 48. DB::Exception: Can't execute any of specified join algorithms for this strictness/kind and right storage type: While processing SELECT a, b, t2_00826.a, t2_00826.b FROM t1_00826 CROSS JOIN t2_00826 WHERE a = b ORDER BY ALL ASC. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36866) (comment: 00826_cross_to_inner_join.sql) (query 51, line 64) (in query: EXPLAIN SYNTAX select * from t1_00826 cross join t2_00826 where t1_00826.a = t1_00826.b order by all;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/ExpressionAnalyzer.cpp:1077: DB::SelectQueryExpressionAnalyzer::makeJoin(DB::ASTTablesInSelectQueryElement const&, std::vector> const&, std::optional&) @ 0x0000000014453e9c 5. /build/src/Interpreters/ExpressionAnalyzer.cpp:976: DB::SelectQueryExpressionAnalyzer::appendJoin(DB::ExpressionActionsChain&, std::shared_ptr&) @ 0x0000000014451469 6. /build/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&) @ 0x000000001445d94d 7. /build/src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x00000000148700e8 8. /build/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 @ 0x00000000148674c4 9. /build/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) @ 0x0000000014862327 10. /build/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) @ 0x000000001485ec6c 11. /build/src/Interpreters/InterpreterSelectQuery.cpp:305: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001485e9b1 12. /build/src/Interpreters/InterpreterExplainQuery.cpp:81: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x000000001483fffb 13. /build/src/Interpreters/InDepthNodeVisitor.h:61: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x0000000014840290 14. /build/src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000001484029b 15. /build/src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000001484029b 16. /build/src/Interpreters/InDepthNodeVisitor.h:64: DB::InterpreterExplainQuery::executeImpl() @ 0x0000000014839b7b 17. /build/src/Interpreters/InterpreterExplainQuery.cpp:130: DB::InterpreterExplainQuery::execute() @ 0x0000000014838307 18. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:10:02.447759 [ 6612 ] {} TCPHandler: Code: 48. DB::Exception: Can't execute any of specified join algorithms for this strictness/kind and right storage type: While processing SELECT a, b, t2_00826.a, t2_00826.b FROM t1_00826 CROSS JOIN t2_00826 WHERE a = b ORDER BY ALL ASC. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/ExpressionAnalyzer.cpp:1077: DB::SelectQueryExpressionAnalyzer::makeJoin(DB::ASTTablesInSelectQueryElement const&, std::vector> const&, std::optional&) @ 0x0000000014453e9c 5. /build/src/Interpreters/ExpressionAnalyzer.cpp:976: DB::SelectQueryExpressionAnalyzer::appendJoin(DB::ExpressionActionsChain&, std::shared_ptr&) @ 0x0000000014451469 6. /build/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&) @ 0x000000001445d94d 7. /build/src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x00000000148700e8 8. /build/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 @ 0x00000000148674c4 9. /build/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) @ 0x0000000014862327 10. /build/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) @ 0x000000001485ec6c 11. /build/src/Interpreters/InterpreterSelectQuery.cpp:305: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001485e9b1 12. /build/src/Interpreters/InterpreterExplainQuery.cpp:81: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x000000001483fffb 13. /build/src/Interpreters/InDepthNodeVisitor.h:61: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x0000000014840290 14. /build/src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000001484029b 15. /build/src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000001484029b 16. /build/src/Interpreters/InDepthNodeVisitor.h:64: DB::InterpreterExplainQuery::executeImpl() @ 0x0000000014839b7b 17. /build/src/Interpreters/InterpreterExplainQuery.cpp:130: DB::InterpreterExplainQuery::execute() @ 0x0000000014838307 18. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:10:03.677232 [ 3543 ] {c86dcf2a-6b74-4137-88eb-ebccfce5ad7f} 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]:52742) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000009fbd84b 4. /build/src/Functions/FunctionsLogical.cpp:542: DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000012cb015a 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5148: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f66bff 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:10:03.684790 [ 3543 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000009fbd84b 4. /build/src/Functions/FunctionsLogical.cpp:542: DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000012cb015a 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5148: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f66bff 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:10:03.882621 [ 3543 ] {dfc4d935-f602-4e61-bab7-e0815fdc47d6} 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]:52742) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000009fbd84b 4. /build/src/Functions/FunctionsLogical.cpp:542: DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000012cb015a 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5148: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f66bff 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:10:03.894734 [ 3543 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000009fbd84b 4. /build/src/Functions/FunctionsLogical.cpp:542: DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000012cb015a 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5148: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f66bff 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:10:05.930268 [ 6619 ] {75240bdd-7168-41be-ab72-8afc4aaa8257} executeQuery: Code: 59. DB::Exception: Illegal type Float32 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]:50316) (comment: 01917_prewhere_column_type.sql) (query 9, line 13) (in query: SELECT s FROM t1 PREWHERE f;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Columns/FilterDescription.cpp:98: DB::FilterDescription::FilterDescription(DB::IColumn const&) @ 0x0000000015bcfef4 5. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:95: DB::FilterWithCachedCount::FilterWithCachedCount(COW::immutable_ptr const&) @ 0x00000000163c799a 6. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:1435: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) const @ 0x00000000163c618f 7. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:110: DB::MergeTreeReadersChain::executePrewhereActions(DB::MergeTreeRangeReader&, DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) @ 0x00000000163df584 8. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:75: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x00000000163dedc4 9. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x00000000163dace0 10. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x0000000016d7ba8c 11. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5584 12. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 13. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 17. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 18. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 19. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 22. ? @ 0x00007f7210eb6ac3 23. ? @ 0x00007f7210f48850 2025.07.13 02:10:05.939174 [ 6619 ] {} TCPHandler: Code: 59. DB::Exception: Illegal type Float32 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Columns/FilterDescription.cpp:98: DB::FilterDescription::FilterDescription(DB::IColumn const&) @ 0x0000000015bcfef4 5. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:95: DB::FilterWithCachedCount::FilterWithCachedCount(COW::immutable_ptr const&) @ 0x00000000163c799a 6. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:1435: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) const @ 0x00000000163c618f 7. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:110: DB::MergeTreeReadersChain::executePrewhereActions(DB::MergeTreeRangeReader&, DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) @ 0x00000000163df584 8. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:75: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x00000000163dedc4 9. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x00000000163dace0 10. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x0000000016d7ba8c 11. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5584 12. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 13. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 17. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 18. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 19. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 22. ? @ 0x00007f7210eb6ac3 23. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:10:06.185413 [ 6619 ] {70729aae-7131-4fbe-a684-5fa0365adfac} executeQuery: Code: 59. DB::Exception: Illegal type Float32 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]:50316) (comment: 01917_prewhere_column_type.sql) (query 10, line 14) (in query: SELECT s FROM t1 PREWHERE f WHERE (e = 1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Columns/FilterDescription.cpp:98: DB::FilterDescription::FilterDescription(DB::IColumn const&) @ 0x0000000015bcfef4 5. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:95: DB::FilterWithCachedCount::FilterWithCachedCount(COW::immutable_ptr const&) @ 0x00000000163c799a 6. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:1435: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) const @ 0x00000000163c618f 7. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:110: DB::MergeTreeReadersChain::executePrewhereActions(DB::MergeTreeRangeReader&, DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) @ 0x00000000163df584 8. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:75: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x00000000163dedc4 9. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x00000000163dace0 10. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x0000000016d7ba8c 11. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5584 12. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 13. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 17. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 18. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 19. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 22. ? @ 0x00007f7210eb6ac3 23. ? @ 0x00007f7210f48850 2025.07.13 02:10:06.199116 [ 6619 ] {} TCPHandler: Code: 59. DB::Exception: Illegal type Float32 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Columns/FilterDescription.cpp:98: DB::FilterDescription::FilterDescription(DB::IColumn const&) @ 0x0000000015bcfef4 5. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:95: DB::FilterWithCachedCount::FilterWithCachedCount(COW::immutable_ptr const&) @ 0x00000000163c799a 6. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:1435: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) const @ 0x00000000163c618f 7. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:110: DB::MergeTreeReadersChain::executePrewhereActions(DB::MergeTreeRangeReader&, DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) @ 0x00000000163df584 8. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:75: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x00000000163dedc4 9. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x00000000163dace0 10. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x0000000016d7ba8c 11. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5584 12. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 13. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 17. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 18. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 19. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 22. ? @ 0x00007f7210eb6ac3 23. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:10:06.538450 [ 6619 ] {08b5b857-123f-4dbf-a6fb-9534364ab812} executeQuery: Code: 59. DB::Exception: Illegal type Float32 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]:50316) (comment: 01917_prewhere_column_type.sql) (query 11, line 15) (in query: SELECT s FROM t1 PREWHERE f WHERE f AND (e = 1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Columns/FilterDescription.cpp:98: DB::FilterDescription::FilterDescription(DB::IColumn const&) @ 0x0000000015bcfef4 5. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:95: DB::FilterWithCachedCount::FilterWithCachedCount(COW::immutable_ptr const&) @ 0x00000000163c799a 6. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:1435: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) const @ 0x00000000163c618f 7. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:110: DB::MergeTreeReadersChain::executePrewhereActions(DB::MergeTreeRangeReader&, DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) @ 0x00000000163df584 8. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:75: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x00000000163dedc4 9. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x00000000163dace0 10. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x0000000016d7ba8c 11. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5584 12. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 13. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 17. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 18. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 19. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 22. ? @ 0x00007f7210eb6ac3 23. ? @ 0x00007f7210f48850 2025.07.13 02:10:06.563496 [ 6619 ] {} TCPHandler: Code: 59. DB::Exception: Illegal type Float32 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Columns/FilterDescription.cpp:98: DB::FilterDescription::FilterDescription(DB::IColumn const&) @ 0x0000000015bcfef4 5. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:95: DB::FilterWithCachedCount::FilterWithCachedCount(COW::immutable_ptr const&) @ 0x00000000163c799a 6. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:1435: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) const @ 0x00000000163c618f 7. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:110: DB::MergeTreeReadersChain::executePrewhereActions(DB::MergeTreeRangeReader&, DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) @ 0x00000000163df584 8. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:75: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x00000000163dedc4 9. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x00000000163dace0 10. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x0000000016d7ba8c 11. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5584 12. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 13. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 17. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 18. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 19. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 22. ? @ 0x00007f7210eb6ac3 23. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:10:07.554662 [ 6619 ] {cfbecc54-654e-4823-9b2d-dabf65060629} executeQuery: Code: 59. DB::Exception: Illegal type UInt16 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]:50316) (comment: 01917_prewhere_column_type.sql) (query 13, line 18) (in query: SELECT s FROM t1 PREWHERE e;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Columns/FilterDescription.cpp:98: DB::FilterDescription::FilterDescription(DB::IColumn const&) @ 0x0000000015bcfef4 5. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:95: DB::FilterWithCachedCount::FilterWithCachedCount(COW::immutable_ptr const&) @ 0x00000000163c799a 6. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:1435: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) const @ 0x00000000163c618f 7. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:110: DB::MergeTreeReadersChain::executePrewhereActions(DB::MergeTreeRangeReader&, DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) @ 0x00000000163df584 8. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:75: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x00000000163dedc4 9. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x00000000163dace0 10. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x0000000016d7ba8c 11. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5584 12. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 13. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 17. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 18. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 19. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 22. ? @ 0x00007f7210eb6ac3 23. ? @ 0x00007f7210f48850 2025.07.13 02:10:07.593848 [ 6619 ] {} TCPHandler: Code: 59. DB::Exception: Illegal type UInt16 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Columns/FilterDescription.cpp:98: DB::FilterDescription::FilterDescription(DB::IColumn const&) @ 0x0000000015bcfef4 5. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:95: DB::FilterWithCachedCount::FilterWithCachedCount(COW::immutable_ptr const&) @ 0x00000000163c799a 6. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:1435: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) const @ 0x00000000163c618f 7. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:110: DB::MergeTreeReadersChain::executePrewhereActions(DB::MergeTreeRangeReader&, DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) @ 0x00000000163df584 8. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:75: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x00000000163dedc4 9. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x00000000163dace0 10. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x0000000016d7ba8c 11. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5584 12. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 13. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 17. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 18. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 19. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 22. ? @ 0x00007f7210eb6ac3 23. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:10:08.012711 [ 6619 ] {594292d5-70cf-4436-b5da-b3ed4ecdbb0d} executeQuery: Code: 59. DB::Exception: Illegal type UInt16 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]:50316) (comment: 01917_prewhere_column_type.sql) (query 14, line 19) (in query: SELECT s FROM t1 PREWHERE e WHERE (e = 1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Columns/FilterDescription.cpp:98: DB::FilterDescription::FilterDescription(DB::IColumn const&) @ 0x0000000015bcfef4 5. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:95: DB::FilterWithCachedCount::FilterWithCachedCount(COW::immutable_ptr const&) @ 0x00000000163c799a 6. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:1435: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) const @ 0x00000000163c618f 7. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:110: DB::MergeTreeReadersChain::executePrewhereActions(DB::MergeTreeRangeReader&, DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) @ 0x00000000163df584 8. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:75: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x00000000163dedc4 9. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x00000000163dace0 10. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x0000000016d7ba8c 11. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5584 12. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 13. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 17. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 18. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 19. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 22. ? @ 0x00007f7210eb6ac3 23. ? @ 0x00007f7210f48850 2025.07.13 02:10:08.044675 [ 6619 ] {} TCPHandler: Code: 59. DB::Exception: Illegal type UInt16 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Columns/FilterDescription.cpp:98: DB::FilterDescription::FilterDescription(DB::IColumn const&) @ 0x0000000015bcfef4 5. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:95: DB::FilterWithCachedCount::FilterWithCachedCount(COW::immutable_ptr const&) @ 0x00000000163c799a 6. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:1435: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) const @ 0x00000000163c618f 7. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:110: DB::MergeTreeReadersChain::executePrewhereActions(DB::MergeTreeRangeReader&, DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) @ 0x00000000163df584 8. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:75: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x00000000163dedc4 9. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x00000000163dace0 10. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x0000000016d7ba8c 11. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5584 12. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 13. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 17. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 18. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 19. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 22. ? @ 0x00007f7210eb6ac3 23. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:10:08.426852 [ 6619 ] {9c81dfba-6f06-4e3e-8051-e3a4d5d53bde} executeQuery: Code: 59. DB::Exception: Illegal type UInt16 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]:50316) (comment: 01917_prewhere_column_type.sql) (query 15, line 20) (in query: SELECT s FROM t1 PREWHERE e WHERE f AND (e = 1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Columns/FilterDescription.cpp:98: DB::FilterDescription::FilterDescription(DB::IColumn const&) @ 0x0000000015bcfef4 5. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:95: DB::FilterWithCachedCount::FilterWithCachedCount(COW::immutable_ptr const&) @ 0x00000000163c799a 6. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:1435: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) const @ 0x00000000163c618f 7. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:110: DB::MergeTreeReadersChain::executePrewhereActions(DB::MergeTreeRangeReader&, DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) @ 0x00000000163df584 8. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:75: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x00000000163dedc4 9. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x00000000163dace0 10. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x0000000016d7ba8c 11. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5584 12. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 13. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 17. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 18. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 19. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 22. ? @ 0x00007f7210eb6ac3 23. ? @ 0x00007f7210f48850 2025.07.13 02:10:08.452984 [ 6619 ] {} TCPHandler: Code: 59. DB::Exception: Illegal type UInt16 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Columns/FilterDescription.cpp:98: DB::FilterDescription::FilterDescription(DB::IColumn const&) @ 0x0000000015bcfef4 5. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:95: DB::FilterWithCachedCount::FilterWithCachedCount(COW::immutable_ptr const&) @ 0x00000000163c799a 6. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:1435: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) const @ 0x00000000163c618f 7. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:110: DB::MergeTreeReadersChain::executePrewhereActions(DB::MergeTreeRangeReader&, DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) @ 0x00000000163df584 8. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:75: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x00000000163dedc4 9. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x00000000163dace0 10. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x0000000016d7ba8c 11. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5584 12. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 13. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 17. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 18. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 19. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 22. ? @ 0x00007f7210eb6ac3 23. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:10:10.990666 [ 5018 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778c58 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168167bf 10. /build/src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000001680ff45 11. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:10:11.012975 [ 5018 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x0000000016810069 5. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 6. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 2025.07.13 02:10:11.275554 [ 16784 ] {35ce8a52-e398-4663-b0cf-3efdda42214f} 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]:43510) (comment: 03173_forbid_qualify.sql) (in query: DROP DATABASE IF EXISTS test_ua5dp3sj SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:10:11.283975 [ 16784 ] {35ce8a52-e398-4663-b0cf-3efdda42214f} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:10:12.391398 [ 5018 ] {e97352a2-0a18-4526-9516-93bfd6a684e0} 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]:52468) (comment: 01715_table_function_view_fix.sql) (query 1, line 3) (in query: SELECT sumIf(dummy, dummy) FROM remote('127.0.0.{1,2}', numbers(2, 100), view(SELECT CAST(NULL, 'Nullable(UInt8)') AS dummy FROM system.one));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Parsers/ASTFunction.cpp:39: DB::ASTFunction::appendColumnNameImpl(DB::WriteBuffer&) const @ 0x00000000178ce7a4 5. /build/src/Parsers/IAST.cpp:255: DB::IAST::getColumnName() const @ 0x0000000017958b17 6. /build/src/Interpreters/ExpressionAnalyzer.cpp:1859: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x000000001445c015 7. /build/src/Interpreters/ExpressionAnalyzer.cpp:1902: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x000000001445c649 8. /build/src/Storages/StorageDistributed.cpp:266: DB::(anonymous namespace)::buildShardingKeyExpression(std::shared_ptr const&, std::shared_ptr, DB::NamesAndTypesList const&, bool) @ 0x0000000015c7e32a 9. /build/src/Storages/StorageDistributed.cpp:408: DB::StorageDistributed::StorageDistributed(DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, String const&, String const&, std::shared_ptr, std::shared_ptr const&, String const&, String const&, DB::DistributedSettings const&, DB::LoadingStrictnessLevel, std::shared_ptr, std::shared_ptr, bool) @ 0x0000000015c7cbcd 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, String const&, String const&, String, std::shared_ptr&, std::shared_ptr const&, String, String, DB::DistributedSettings, DB::LoadingStrictnessLevel, std::shared_ptr const&, std::shared_ptr const&, bool, 0>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, String const&, String const&, String&&, std::shared_ptr&, std::shared_ptr const&, String&&, String&&, DB::DistributedSettings&&, DB::LoadingStrictnessLevel&&, std::shared_ptr const&, std::shared_ptr const&, bool&&) @ 0x0000000011706ae9 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000011702c30 12. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000130d4903 13. /build/src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000143537f2 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3da49 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:10:12.413224 [ 5018 ] {} TCPHandler: Code: 46. DB::Exception: Table function 'view' cannot be used as an expression. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Parsers/ASTFunction.cpp:39: DB::ASTFunction::appendColumnNameImpl(DB::WriteBuffer&) const @ 0x00000000178ce7a4 5. /build/src/Parsers/IAST.cpp:255: DB::IAST::getColumnName() const @ 0x0000000017958b17 6. /build/src/Interpreters/ExpressionAnalyzer.cpp:1859: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x000000001445c015 7. /build/src/Interpreters/ExpressionAnalyzer.cpp:1902: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x000000001445c649 8. /build/src/Storages/StorageDistributed.cpp:266: DB::(anonymous namespace)::buildShardingKeyExpression(std::shared_ptr const&, std::shared_ptr, DB::NamesAndTypesList const&, bool) @ 0x0000000015c7e32a 9. /build/src/Storages/StorageDistributed.cpp:408: DB::StorageDistributed::StorageDistributed(DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, String const&, String const&, std::shared_ptr, std::shared_ptr const&, String const&, String const&, DB::DistributedSettings const&, DB::LoadingStrictnessLevel, std::shared_ptr, std::shared_ptr, bool) @ 0x0000000015c7cbcd 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, String const&, String const&, String, std::shared_ptr&, std::shared_ptr const&, String, String, DB::DistributedSettings, DB::LoadingStrictnessLevel, std::shared_ptr const&, std::shared_ptr const&, bool, 0>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, String const&, String const&, String&&, std::shared_ptr&, std::shared_ptr const&, String&&, String&&, DB::DistributedSettings&&, DB::LoadingStrictnessLevel&&, std::shared_ptr const&, std::shared_ptr const&, bool&&) @ 0x0000000011706ae9 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000011702c30 12. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000130d4903 13. /build/src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000143537f2 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3da49 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:10:19.278471 [ 5987 ] {783ed134-2a09-4264-a2cd-f8a248da8374} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9010 -> [::1]:47210). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47210) (in query: SELECT 'Hello, world'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fc62e75 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fc64467 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x0000000009fb95be 5. /build/src/Server/TCPHandler.cpp:2589: DB::TCPHandler::sendProgress(DB::QueryState&) @ 0x00000000168121dc 6. /build/src/Server/TCPHandler.cpp:1292: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811e07 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:10:19.301298 [ 5987 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9010 -> [::1]:47210). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fc62e75 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fc64467 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x0000000009fb95be 5. /build/src/Server/TCPHandler.cpp:2589: DB::TCPHandler::sendProgress(DB::QueryState&) @ 0x00000000168121dc 6. /build/src/Server/TCPHandler.cpp:1292: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811e07 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:10:19.539658 [ 6611 ] {d0248a39-095a-4f63-bcf7-f7499dea2236} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9010 -> [::1]:47222). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47222) (in query: SELECT 'Hello, world'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fc62e75 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fc64467 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x0000000009fb95be 5. /build/src/Server/TCPHandler.cpp:2589: DB::TCPHandler::sendProgress(DB::QueryState&) @ 0x00000000168121dc 6. /build/src/Server/TCPHandler.cpp:1292: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811e07 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:10:19.554862 [ 6611 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9010 -> [::1]:47222). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fc62e75 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fc64467 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x0000000009fb95be 5. /build/src/Server/TCPHandler.cpp:2589: DB::TCPHandler::sendProgress(DB::QueryState&) @ 0x00000000168121dc 6. /build/src/Server/TCPHandler.cpp:1292: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811e07 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:10:19.638862 [ 4930 ] {7902dbf0-5e9b-44f1-9680-1b82a73f97d2} executeQuery: Code: 36. DB::Exception: CellId is invalid.: In scope SELECT s2ToGeo(toUInt64(-1)). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52426) (comment: 01849_geoToS2.sql) (query 26, line 45) (in query: SELECT s2ToGeo(toUInt64(-1));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/s2ToGeo.cpp:100: DB::(anonymous namespace)::FunctionS2ToGeo::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e58ce1d 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:10:19.655601 [ 4930 ] {} TCPHandler: Code: 36. DB::Exception: CellId is invalid.: In scope SELECT s2ToGeo(toUInt64(-1)). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/s2ToGeo.cpp:100: DB::(anonymous namespace)::FunctionS2ToGeo::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e58ce1d 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:10:19.813470 [ 5987 ] {9adb3f16-8083-457f-82b2-4f506329daba} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9010 -> [::1]:47232). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47232) (in query: SELECT 'Hello, world'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fc62e75 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fc64467 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x0000000009fb95be 5. /build/src/Server/TCPHandler.cpp:2589: DB::TCPHandler::sendProgress(DB::QueryState&) @ 0x00000000168121dc 6. /build/src/Server/TCPHandler.cpp:1292: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811e07 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:10:19.824878 [ 4930 ] {cb7b4482-e2c1-44e8-83b5-1baa7981c196} executeQuery: Code: 43. DB::Exception: Illegal type Float64 of argument 1 of function s2ToGeo. Must be UInt64: In scope SELECT s2ToGeo(nan). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52426) (comment: 01849_geoToS2.sql) (query 27, line 46) (in query: SELECT s2ToGeo(nan);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, int&&, String&&) @ 0x000000000b96964b 4. /build/src/Functions/s2ToGeo.cpp:59: DB::(anonymous namespace)::FunctionS2ToGeo::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000e58d465 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:10:19.825897 [ 5987 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9010 -> [::1]:47232). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fc62e75 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fc64467 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x0000000009fb95be 5. /build/src/Server/TCPHandler.cpp:2589: DB::TCPHandler::sendProgress(DB::QueryState&) @ 0x00000000168121dc 6. /build/src/Server/TCPHandler.cpp:1292: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811e07 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:10:19.831413 [ 4930 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Float64 of argument 1 of function s2ToGeo. Must be UInt64: In scope SELECT s2ToGeo(nan). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, int&&, String&&) @ 0x000000000b96964b 4. /build/src/Functions/s2ToGeo.cpp:59: DB::(anonymous namespace)::FunctionS2ToGeo::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000e58d465 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:10:19.983288 [ 4930 ] {c9259e3c-2c4f-4545-b8eb-bc304e09f79f} executeQuery: Code: 36. DB::Exception: Point (1.8446744073709552e+19, 1.8446744073709552e+19) is invalid in function geoToS2. For valid point the latitude is between -90 and 90 degrees inclusiveand the longitude is between -180 and 180 degrees inclusive.: In scope SELECT geoToS2(toFloat64(toUInt64(-1)), toFloat64(toUInt64(-1))). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52426) (comment: 01849_geoToS2.sql) (query 28, line 47) (in query: SELECT geoToS2(toFloat64(toUInt64(-1)), toFloat64(toUInt64(-1)));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, double const&, double const&, String&&) @ 0x000000000b96bbcb 4. /build/src/Functions/geoToS2.cpp:131: DB::(anonymous namespace)::FunctionGeoToS2::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b96b645 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:10:20.015309 [ 4930 ] {} TCPHandler: Code: 36. DB::Exception: Point (1.8446744073709552e+19, 1.8446744073709552e+19) is invalid in function geoToS2. For valid point the latitude is between -90 and 90 degrees inclusiveand the longitude is between -180 and 180 degrees inclusive.: In scope SELECT geoToS2(toFloat64(toUInt64(-1)), toFloat64(toUInt64(-1))). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, double const&, double const&, String&&) @ 0x000000000b96bbcb 4. /build/src/Functions/geoToS2.cpp:131: DB::(anonymous namespace)::FunctionGeoToS2::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b96b645 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:10:20.100667 [ 4930 ] {a98d3bb2-3444-46cf-8e18-e43db8253a65} executeQuery: Code: 43. DB::Exception: Illegal argument for longitude in function geoToS2. It must not be NaN: In scope SELECT geoToS2(nan, nan). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52426) (comment: 01849_geoToS2.sql) (query 29, line 48) (in query: SELECT geoToS2(nan, nan);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/geoToS2.cpp:110: DB::(anonymous namespace)::FunctionGeoToS2::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b96b39e 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:10:20.124408 [ 4930 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument for longitude in function geoToS2. It must not be NaN: In scope SELECT geoToS2(nan, nan). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/geoToS2.cpp:110: DB::(anonymous namespace)::FunctionGeoToS2::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b96b39e 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:10:20.293272 [ 4930 ] {af1609e1-fe7d-4a9d-b050-4f20f362b7b8} executeQuery: Code: 43. DB::Exception: Illegal argument for longitude in function geoToS2. It must not be infinite: In scope SELECT geoToS2(-inf, 1.1754943508222875e-38). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52426) (comment: 01849_geoToS2.sql) (query 30, line 49) (in query: SELECT geoToS2(-inf, 1.1754943508222875e-38);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/geoToS2.cpp:113: DB::(anonymous namespace)::FunctionGeoToS2::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b96b43d 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:10:20.304845 [ 4930 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument for longitude in function geoToS2. It must not be infinite: In scope SELECT geoToS2(-inf, 1.1754943508222875e-38). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/geoToS2.cpp:113: DB::(anonymous namespace)::FunctionGeoToS2::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b96b43d 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:10:21.359252 [ 6619 ] {acfb0389-c9df-42ce-b56a-359b019e3916} 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]:33026) (comment: 01715_table_function_view_fix.sql) (query 1, line 3) (in query: SELECT sumIf(dummy, dummy) FROM remote('127.0.0.{1,2}', numbers(2, 100), view(SELECT CAST(NULL, 'Nullable(UInt8)') AS dummy FROM system.one));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Parsers/ASTFunction.cpp:39: DB::ASTFunction::appendColumnNameImpl(DB::WriteBuffer&) const @ 0x00000000178ce7a4 5. /build/src/Parsers/IAST.cpp:255: DB::IAST::getColumnName() const @ 0x0000000017958b17 6. /build/src/Interpreters/ExpressionAnalyzer.cpp:1859: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x000000001445c015 7. /build/src/Interpreters/ExpressionAnalyzer.cpp:1902: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x000000001445c649 8. /build/src/Storages/StorageDistributed.cpp:266: DB::(anonymous namespace)::buildShardingKeyExpression(std::shared_ptr const&, std::shared_ptr, DB::NamesAndTypesList const&, bool) @ 0x0000000015c7e32a 9. /build/src/Storages/StorageDistributed.cpp:408: DB::StorageDistributed::StorageDistributed(DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, String const&, String const&, std::shared_ptr, std::shared_ptr const&, String const&, String const&, DB::DistributedSettings const&, DB::LoadingStrictnessLevel, std::shared_ptr, std::shared_ptr, bool) @ 0x0000000015c7cbcd 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, String const&, String const&, String, std::shared_ptr&, std::shared_ptr const&, String, String, DB::DistributedSettings, DB::LoadingStrictnessLevel, std::shared_ptr const&, std::shared_ptr const&, bool, 0>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, String const&, String const&, String&&, std::shared_ptr&, std::shared_ptr const&, String&&, String&&, DB::DistributedSettings&&, DB::LoadingStrictnessLevel&&, std::shared_ptr const&, std::shared_ptr const&, bool&&) @ 0x0000000011706ae9 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000011702c30 12. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000130d4903 13. /build/src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000143537f2 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3da49 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:10:21.373634 [ 6619 ] {} TCPHandler: Code: 46. DB::Exception: Table function 'view' cannot be used as an expression. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Parsers/ASTFunction.cpp:39: DB::ASTFunction::appendColumnNameImpl(DB::WriteBuffer&) const @ 0x00000000178ce7a4 5. /build/src/Parsers/IAST.cpp:255: DB::IAST::getColumnName() const @ 0x0000000017958b17 6. /build/src/Interpreters/ExpressionAnalyzer.cpp:1859: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x000000001445c015 7. /build/src/Interpreters/ExpressionAnalyzer.cpp:1902: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x000000001445c649 8. /build/src/Storages/StorageDistributed.cpp:266: DB::(anonymous namespace)::buildShardingKeyExpression(std::shared_ptr const&, std::shared_ptr, DB::NamesAndTypesList const&, bool) @ 0x0000000015c7e32a 9. /build/src/Storages/StorageDistributed.cpp:408: DB::StorageDistributed::StorageDistributed(DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, String const&, String const&, std::shared_ptr, std::shared_ptr const&, String const&, String const&, DB::DistributedSettings const&, DB::LoadingStrictnessLevel, std::shared_ptr, std::shared_ptr, bool) @ 0x0000000015c7cbcd 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, String const&, String const&, String, std::shared_ptr&, std::shared_ptr const&, String, String, DB::DistributedSettings, DB::LoadingStrictnessLevel, std::shared_ptr const&, std::shared_ptr const&, bool, 0>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, String const&, String const&, String&&, std::shared_ptr&, std::shared_ptr const&, String&&, String&&, DB::DistributedSettings&&, DB::LoadingStrictnessLevel&&, std::shared_ptr const&, std::shared_ptr const&, bool&&) @ 0x0000000011706ae9 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000011702c30 12. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000130d4903 13. /build/src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000143537f2 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3da49 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:10:21.896524 [ 6612 ] {6d7cafe2-21fb-4460-ab12-532d7fce5db5} executeQuery: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33048) (query 1, line 1) (in query: select _path,_file from file('nonexist.txt', 'CSV', 'val1 char')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Storages/StorageFile.cpp:1630: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000015caf8eb 5. /build/src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000148b600e 6. /build/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&) @ 0x00000000148ad029 7. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 8. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 10. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:10:21.920832 [ 6612 ] {} TCPHandler: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Storages/StorageFile.cpp:1630: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000015caf8eb 5. /build/src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000148b600e 6. /build/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&) @ 0x00000000148ad029 7. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 8. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 10. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:10:24.575355 [ 6532 ] {0fc2c937-4e82-420e-a03d-a4887f39795a} executeQuery: Code: 1. DB::Exception: Resolved identifier 'age_max' in parent scope to expression 'test_3.users.age' with correlated column 'age'. In scope (SELECT uid FROM users WHERE users.age < age_max ORDER BY users.age DESC LIMIT 1). (UNSUPPORTED_METHOD) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33058) (comment: 03314_analyzer_resolve_in_parent_scope_4.sql) (query 8, line 20) (in query: SELECT *, oldest_before(users.age) FROM users;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String const&, String&&) @ 0x0000000013f68c6b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1382: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000013f4992c 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1544: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000013f4893d 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f392f4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3236a 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38a1e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2670: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x0000000013f5cf61 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3179: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f50a55 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:10:24.600355 [ 4930 ] {45a80220-4968-4a3d-b138-cea683f4758b} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 32 (DROP): DROP COLUMN c. Expected one of: ALTER command, token, OpeningRoundBracket: In scope SELECT formatQuery('ALTER TABLE a (DROP COLUMN b), DROP COLUMN c'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33070) (comment: 02982_unambiguous_alter_commands.sql) (query 5, line 6) (in query: SELECT formatQuery('ALTER TABLE a (DROP COLUMN b), DROP COLUMN c');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000009fd29ed 3. /build/src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9acc 4. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 5. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:10:24.612696 [ 6532 ] {} TCPHandler: Code: 1. DB::Exception: Resolved identifier 'age_max' in parent scope to expression 'test_3.users.age' with correlated column 'age'. In scope (SELECT uid FROM users WHERE users.age < age_max ORDER BY users.age DESC LIMIT 1). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String const&, String&&) @ 0x0000000013f68c6b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1382: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000013f4992c 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1544: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000013f4893d 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f392f4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3236a 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38a1e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2670: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x0000000013f5cf61 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3179: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f50a55 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:10:24.643787 [ 4930 ] {} TCPHandler: Code: 62. DB::Exception: Syntax error: failed at position 32 (DROP): DROP COLUMN c. Expected one of: ALTER command, token, OpeningRoundBracket: In scope SELECT formatQuery('ALTER TABLE a (DROP COLUMN b), DROP COLUMN c'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000009fd29ed 3. /build/src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9acc 4. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 5. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:10:24.801024 [ 4930 ] {bf6257b3-666a-4ab0-b821-940b40d88d0c} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 30 ((): (DROP COLUMN c). Expected one of: ALTER command, ADD COLUMN, RENAME COLUMN, MATERIALIZE COLUMN, DROP PARTITION, DROP PART, FORGET PARTITION, DROP DETACHED PARTITION, DROP DETACHED PART, DROP COLUMN, CLEAR COLUMN, ADD INDEX, DROP INDEX, CLEAR INDEX, MATERIALIZE INDEX, ADD STATISTICS, MODIFY STATISTICS, DROP STATISTICS, CLEAR STATISTICS, MATERIALIZE STATISTICS, ADD PROJECTION, DROP PROJECTION, CLEAR PROJECTION, MATERIALIZE PROJECTION, MOVE PART, MOVE PARTITION, ADD CONSTRAINT, DROP CONSTRAINT, DETACH PARTITION, DETACH PART, ATTACH PARTITION, REPLACE PARTITION, ATTACH PART, FETCH PARTITION, FETCH PART, FREEZE, UNFREEZE, UNLOCK SNAPSHOT, MODIFY COLUMN, ALTER COLUMN, MODIFY ORDER BY, MODIFY SAMPLE BY, REMOVE SAMPLE BY, DELETE, UPDATE, COMMENT COLUMN, MODIFY TTL, REMOVE TTL, MATERIALIZE TTL, MODIFY SETTING, RESET SETTING, MODIFY QUERY, MODIFY SQL SECURITY, MODIFY DEFINER, MODIFY REFRESH, MODIFY COMMENT, APPLY DELETED MASK: In scope SELECT formatQuery('ALTER TABLE a DROP COLUMN b, (DROP COLUMN c)'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33070) (comment: 02982_unambiguous_alter_commands.sql) (query 6, line 7) (in query: SELECT formatQuery('ALTER TABLE a DROP COLUMN b, (DROP COLUMN c)');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000009fd29ed 3. /build/src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9acc 4. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 5. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:10:24.809238 [ 4930 ] {} TCPHandler: Code: 62. DB::Exception: Syntax error: failed at position 30 ((): (DROP COLUMN c). Expected one of: ALTER command, ADD COLUMN, RENAME COLUMN, MATERIALIZE COLUMN, DROP PARTITION, DROP PART, FORGET PARTITION, DROP DETACHED PARTITION, DROP DETACHED PART, DROP COLUMN, CLEAR COLUMN, ADD INDEX, DROP INDEX, CLEAR INDEX, MATERIALIZE INDEX, ADD STATISTICS, MODIFY STATISTICS, DROP STATISTICS, CLEAR STATISTICS, MATERIALIZE STATISTICS, ADD PROJECTION, DROP PROJECTION, CLEAR PROJECTION, MATERIALIZE PROJECTION, MOVE PART, MOVE PARTITION, ADD CONSTRAINT, DROP CONSTRAINT, DETACH PARTITION, DETACH PART, ATTACH PARTITION, REPLACE PARTITION, ATTACH PART, FETCH PARTITION, FETCH PART, FREEZE, UNFREEZE, UNLOCK SNAPSHOT, MODIFY COLUMN, ALTER COLUMN, MODIFY ORDER BY, MODIFY SAMPLE BY, REMOVE SAMPLE BY, DELETE, UPDATE, COMMENT COLUMN, MODIFY TTL, REMOVE TTL, MATERIALIZE TTL, MODIFY SETTING, RESET SETTING, MODIFY QUERY, MODIFY SQL SECURITY, MODIFY DEFINER, MODIFY REFRESH, MODIFY COMMENT, APPLY DELETED MASK: In scope SELECT formatQuery('ALTER TABLE a DROP COLUMN b, (DROP COLUMN c)'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000009fd29ed 3. /build/src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9acc 4. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 5. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:10:26.549477 [ 6166 ] {878b80cf-9946-4371-9721-4c1c2cb1de59} 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]:52570) (comment: 01283_max_threads_simple_query_optimization.sql) (query 11, line 18) (in query: -- 1 for PullingAsyncPipelineExecutor::pull SELECT throwIf(count() != 1, 'no query was logged'), throwIf(length(thread_ids) > 2, 'too many threads used') FROM system.query_log WHERE current_database = currentDatabase() AND type = 'QueryFinish' AND query LIKE '%data_01283 LIMIT 1%' GROUP BY thread_ids FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbdb1ad 7. /build/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) @ 0x000000001631ac2d 8. /build/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) @ 0x0000000016d5067d 9. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x0000000016d4f5b9 10. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x0000000016d4f3b2 11. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d571cc 12. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016cf6870 13. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:10:26.584682 [ 6166 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbdb1ad 7. /build/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) @ 0x000000001631ac2d 8. /build/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) @ 0x0000000016d5067d 9. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x0000000016d4f5b9 10. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x0000000016d4f3b2 11. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d571cc 12. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016cf6870 13. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:10:27.006080 [ 6614 ] {f697fc4e-ecfa-403e-8e04-170e57e05251} 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]:33092) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000013af9d2b 4. /build/src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013af96d2 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000016b4227b 6. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 7. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 10. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 11. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 12. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:10:27.125012 [ 6614 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000013af9d2b 4. /build/src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013af96d2 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000016b4227b 6. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 7. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 10. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 11. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 12. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:10:27.127181 [ 5117 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:51788, local: [::ffff:127.0.0.2]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fc62e75 3. /build/src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000fc623ee 4. /build/src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000fc62923 5. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 6. /build/src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000001680643e 7. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 12. ? @ 0x00007f7210eb6ac3 13. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:10:27.129150 [ 5117 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:51788, local: [::ffff:127.0.0.2]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fc62e75 3. /build/src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000fc623ee 4. /build/src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000fc62923 5. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 6. /build/src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000001680643e 7. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 12. ? @ 0x00007f7210eb6ac3 13. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:10:28.364006 [ 4930 ] {28d89edc-4672-4f5c-a095-891e00e2dc20} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 2 (error): error here . Expected one of: Query, Query with output, EXPLAIN, EXPLAIN, SELECT query, possibly with UNION, list of union elements, SELECT query, subquery, possibly with UNION, SELECT subquery, SELECT query, WITH, FROM, SELECT, SHOW CREATE QUOTA query, SHOW CREATE, SHOW [FULL] [TEMPORARY] TABLES|DATABASES|CLUSTERS|CLUSTER|MERGES 'name' [[NOT] [I]LIKE 'str'] [LIMIT expr], SHOW, SHOW COLUMNS query, SHOW ENGINES query, SHOW ENGINES, SHOW FUNCTIONS query, SHOW FUNCTIONS, SHOW INDEXES query, SHOW SETTING query, SHOW SETTING, EXISTS or SHOW CREATE query, EXISTS, DESCRIBE FILESYSTEM CACHE query, DESCRIBE, DESC, DESCRIBE query, SHOW PROCESSLIST query, SHOW PROCESSLIST, CREATE TABLE or ATTACH TABLE query, CREATE, ATTACH, REPLACE, CREATE DATABASE query, CREATE VIEW query, CREATE DICTIONARY, CREATE LIVE VIEW query, CREATE WINDOW VIEW query, ALTER query, ALTER TABLE, ALTER TEMPORARY TABLE, ALTER DATABASE, RENAME query, RENAME DATABASE, RENAME TABLE, EXCHANGE TABLES, RENAME DICTIONARY, EXCHANGE DICTIONARIES, RENAME, DROP query, DROP, DETACH, TRUNCATE, UNDROP query, UNDROP, CHECK ALL TABLES, CHECK TABLE, KILL QUERY query, KILL, OPTIMIZE query, OPTIMIZE TABLE, WATCH query, WATCH, SHOW ACCESS query, SHOW ACCESS, ShowAccessEntitiesQuery, SHOW GRANTS query, SHOW GRANTS, SHOW PRIVILEGES query, SHOW PRIVILEGES, BACKUP or RESTORE query, BACKUP, RESTORE, INSERT query, INSERT INTO, USE query, USE, SET ROLE or SET DEFAULT ROLE query, SET ROLE DEFAULT, SET ROLE, SET DEFAULT ROLE, SET query, SET, SYSTEM query, SYSTEM, CREATE USER or ALTER USER query, ALTER USER, CREATE USER, CREATE ROLE or ALTER ROLE query, ALTER ROLE, CREATE ROLE, CREATE QUOTA or ALTER QUOTA query, ALTER QUOTA, CREATE QUOTA, CREATE ROW POLICY or ALTER ROW POLICY query, ALTER POLICY, ALTER ROW POLICY, CREATE POLICY, CREATE ROW POLICY, CREATE SETTINGS PROFILE or ALTER SETTINGS PROFILE query, ALTER SETTINGS PROFILE, ALTER PROFILE, CREATE SETTINGS PROFILE, CREATE PROFILE, CREATE FUNCTION query, DROP FUNCTION query, CREATE WORKLOAD query, DROP WORKLOAD query, CREATE RESOURCE query, DROP RESOURCE query, CREATE NAMED COLLECTION, DROP NAMED COLLECTION query, Alter NAMED COLLECTION query, ALTER, CREATE INDEX query, DROP INDEX query, DROP access entity query, MOVE access entity query, MOVE, GRANT or REVOKE query, REVOKE, GRANT, CHECK GRANT, CHECK GRANT, EXTERNAL DDL query, EXTERNAL DDL FROM, TCL query, BEGIN TRANSACTION, START TRANSACTION, COMMIT, ROLLBACK, SET TRANSACTION SNAPSHOT, Delete query, DELETE. (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:45586) (in query: error here ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000009fd29ed 3. /build/src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9acc 4. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 5. /build/src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba32be 6. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 7. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 8. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 9. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:10:28.377158 [ 4930 ] {28d89edc-4672-4f5c-a095-891e00e2dc20} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 2 (error): error here . Expected one of: Query, Query with output, EXPLAIN, EXPLAIN, SELECT query, possibly with UNION, list of union elements, SELECT query, subquery, possibly with UNION, SELECT subquery, SELECT query, WITH, FROM, SELECT, SHOW CREATE QUOTA query, SHOW CREATE, SHOW [FULL] [TEMPORARY] TABLES|DATABASES|CLUSTERS|CLUSTER|MERGES 'name' [[NOT] [I]LIKE 'str'] [LIMIT expr], SHOW, SHOW COLUMNS query, SHOW ENGINES query, SHOW ENGINES, SHOW FUNCTIONS query, SHOW FUNCTIONS, SHOW INDEXES query, SHOW SETTING query, SHOW SETTING, EXISTS or SHOW CREATE query, EXISTS, DESCRIBE FILESYSTEM CACHE query, DESCRIBE, DESC, DESCRIBE query, SHOW PROCESSLIST query, SHOW PROCESSLIST, CREATE TABLE or ATTACH TABLE query, CREATE, ATTACH, REPLACE, CREATE DATABASE query, CREATE VIEW query, CREATE DICTIONARY, CREATE LIVE VIEW query, CREATE WINDOW VIEW query, ALTER query, ALTER TABLE, ALTER TEMPORARY TABLE, ALTER DATABASE, RENAME query, RENAME DATABASE, RENAME TABLE, EXCHANGE TABLES, RENAME DICTIONARY, EXCHANGE DICTIONARIES, RENAME, DROP query, DROP, DETACH, TRUNCATE, UNDROP query, UNDROP, CHECK ALL TABLES, CHECK TABLE, KILL QUERY query, KILL, OPTIMIZE query, OPTIMIZE TABLE, WATCH query, WATCH, SHOW ACCESS query, SHOW ACCESS, ShowAccessEntitiesQuery, SHOW GRANTS query, SHOW GRANTS, SHOW PRIVILEGES query, SHOW PRIVILEGES, BACKUP or RESTORE query, BACKUP, RESTORE, INSERT query, INSERT INTO, USE query, USE, SET ROLE or SET DEFAULT ROLE query, SET ROLE DEFAULT, SET ROLE, SET DEFAULT ROLE, SET query, SET, SYSTEM query, SYSTEM, CREATE USER or ALTER USER query, ALTER USER, CREATE USER, CREATE ROLE or ALTER ROLE query, ALTER ROLE, CREATE ROLE, CREATE QUOTA or ALTER QUOTA query, ALTER QUOTA, CREATE QUOTA, CREATE ROW POLICY or ALTER ROW POLICY query, ALTER POLICY, ALTER ROW POLICY, CREATE POLICY, CREATE ROW POLICY, CREATE SETTINGS PROFILE or ALTER SETTINGS PROFILE query, ALTER SETTINGS PROFILE, ALTER PROFILE, CREATE SETTINGS PROFILE, CREATE PROFILE, CREATE FUNCTION query, DROP FUNCTION query, CREATE WORKLOAD query, DROP WORKLOAD query, CREATE RESOURCE query, DROP RESOURCE query, CREATE NAMED COLLECTION, DROP NAMED COLLECTION query, Alter NAMED COLLECTION query, ALTER, CREATE INDEX query, DROP INDEX query, DROP access entity query, MOVE access entity query, MOVE, GRANT or REVOKE query, REVOKE, GRANT, CHECK GRANT, CHECK GRANT, EXTERNAL DDL query, EXTERNAL DDL FROM, TCL query, BEGIN TRANSACTION, START TRANSACTION, COMMIT, ROLLBACK, SET TRANSACTION SNAPSHOT, Delete query, DELETE. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000009fd29ed 3. /build/src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9acc 4. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 5. /build/src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba32be 6. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 7. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 8. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 9. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:10:29.325432 [ 16784 ] {a8893460-8e05-43c8-9567-65b03691e943} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `non_existent_column` in scope WITH table_0 AS (SELECT * FROM system.users) SELECT non_existent_column FROM table_0. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52454) (comment: 02766_prql.sh) (query 13, line 51) (in query: from s"SELECT * FROM system.users" | select non_existent_column;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000013f69e39 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f3a889 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:10:29.339984 [ 16784 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `non_existent_column` in scope WITH table_0 AS (SELECT * FROM system.users) SELECT non_existent_column FROM table_0. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000013f69e39 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f3a889 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:10:30.085273 [ 3543 ] {82616970-2b3b-4370-a57c-aa01795f0e32} 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]:33200) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000013af9d2b 4. /build/src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013af96d2 5. /build/src/Interpreters/HashJoin/HashJoin.cpp:767: DB::HashJoin::addBlockToJoin(DB::ScatteredBlock&, bool) @ 0x0000000014c9d32a 6. /build/src/Interpreters/HashJoin/HashJoin.cpp:553: DB::HashJoin::addBlockToJoin(DB::Block const&, bool) @ 0x0000000014c99907 7. /build/src/Processors/Transforms/JoiningTransform.cpp:357: DB::FillingRightJoinSideTransform::work() @ 0x0000000016b3c003 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 10. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 11. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 12. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:10:30.124454 [ 3543 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000013af9d2b 4. /build/src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013af96d2 5. /build/src/Interpreters/HashJoin/HashJoin.cpp:767: DB::HashJoin::addBlockToJoin(DB::ScatteredBlock&, bool) @ 0x0000000014c9d32a 6. /build/src/Interpreters/HashJoin/HashJoin.cpp:553: DB::HashJoin::addBlockToJoin(DB::Block const&, bool) @ 0x0000000014c99907 7. /build/src/Processors/Transforms/JoiningTransform.cpp:357: DB::FillingRightJoinSideTransform::work() @ 0x0000000016b3c003 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 10. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 11. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 12. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:10:31.479085 [ 16784 ] {17d03adf-01e7-4f07-8359-e005d7bc2927} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'non_existent_table' in scope SELECT * FROM non_existent_table. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52454) (comment: 02766_prql.sh) (query 14, line 52) (in query: from non_existent_table;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f633d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:10:31.491930 [ 16784 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'non_existent_table' in scope SELECT * FROM non_existent_table. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f633d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:10:38.494856 [ 5121 ] {46726619-86f1-49b1-83b5-7820c58abecd} 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]:46702) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Storages/AlterCommands.cpp:1322: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000015c11912 5. /build/src/Storages/MergeTree/MergeTreeData.cpp:3533: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001625916b 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd033 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 10. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:10:38.521201 [ 5121 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Storages/AlterCommands.cpp:1322: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000015c11912 5. /build/src/Storages/MergeTree/MergeTreeData.cpp:3533: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001625916b 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd033 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 10. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:10:38.868929 [ 5121 ] {f6372a7c-89d3-4849-9191-b52c03b66e71} 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]:46702) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/FunctionsConversion.h:3856: DB::detail::FunctionCast::createAggregateFunctionWrapper(std::shared_ptr const&, DB::DataTypeAggregateFunction const*) const @ 0x0000000012cdb904 5. /build/src/Functions/FunctionsConversion.h:6108: DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000012cd8cff 6. /build/src/Functions/FunctionsConversion.h:5819: DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000012cc817b 7. /build/src/Functions/FunctionsConversion.h:5746: DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000012cc6f09 8. /build/src/Functions/FunctionsConversion.h:3444: DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x0000000012cc67f0 9. /build/src/Interpreters/ActionsDAG.cpp:403: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x0000000013eba709 10. /build/src/Interpreters/ActionsDAG.cpp:330: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x0000000013eb9e43 11. /build/src/Interpreters/ActionsVisitor.cpp:697: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000014477251 12. /build/src/Interpreters/ActionsMatcher.h:178: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000014484aaf 13. /build/src/Interpreters/ActionsVisitor.cpp:1366: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000014479512 14. /build/src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000001446f1d5 15. /build/src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x000000001444cf68 16. /build/src/Interpreters/ExpressionAnalyzer.cpp:1867: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x000000001445c216 17. /build/src/Interpreters/inplaceBlockConversions.cpp:172: DB::(anonymous namespace)::createExpressions(DB::Block const&, std::shared_ptr, bool, std::shared_ptr) @ 0x0000000014bbf56c 18. /build/src/Interpreters/inplaceBlockConversions.cpp:184: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000014bbefba 19. /build/src/Storages/AlterCommands.cpp:1325: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000015c11496 20. /build/src/Storages/MergeTree/MergeTreeData.cpp:3533: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001625916b 21. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd033 22. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 23. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 25. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 26. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 31. ? @ 0x00007f7210eb6ac3 2025.07.13 02:10:38.913675 [ 5121 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/FunctionsConversion.h:3856: DB::detail::FunctionCast::createAggregateFunctionWrapper(std::shared_ptr const&, DB::DataTypeAggregateFunction const*) const @ 0x0000000012cdb904 5. /build/src/Functions/FunctionsConversion.h:6108: DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000012cd8cff 6. /build/src/Functions/FunctionsConversion.h:5819: DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000012cc817b 7. /build/src/Functions/FunctionsConversion.h:5746: DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000012cc6f09 8. /build/src/Functions/FunctionsConversion.h:3444: DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x0000000012cc67f0 9. /build/src/Interpreters/ActionsDAG.cpp:403: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x0000000013eba709 10. /build/src/Interpreters/ActionsDAG.cpp:330: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x0000000013eb9e43 11. /build/src/Interpreters/ActionsVisitor.cpp:697: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000014477251 12. /build/src/Interpreters/ActionsMatcher.h:178: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000014484aaf 13. /build/src/Interpreters/ActionsVisitor.cpp:1366: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000014479512 14. /build/src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000001446f1d5 15. /build/src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x000000001444cf68 16. /build/src/Interpreters/ExpressionAnalyzer.cpp:1867: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x000000001445c216 17. /build/src/Interpreters/inplaceBlockConversions.cpp:172: DB::(anonymous namespace)::createExpressions(DB::Block const&, std::shared_ptr, bool, std::shared_ptr) @ 0x0000000014bbf56c 18. /build/src/Interpreters/inplaceBlockConversions.cpp:184: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000014bbefba 19. /build/src/Storages/AlterCommands.cpp:1325: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000015c11496 20. /build/src/Storages/MergeTree/MergeTreeData.cpp:3533: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001625916b 21. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd033 22. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 23. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 25. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 26. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 31. ? @ 0x00007f7210eb6ac3 2025.07.13 02:10:46.335274 [ 16763 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778c58 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168167bf 10. /build/src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000001680ff45 11. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:10:46.349297 [ 16763 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x0000000016810069 5. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 6. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 2025.07.13 02:10:47.662711 [ 5998 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000013779f8b 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000137794b8 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778bc3 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678d325 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:10:48.463204 [ 3543 ] {46f71be1-f887-44c6-8812-0e11a8399e75} 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]:56944) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000013f69e39 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f3a889 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:10:48.540326 [ 3543 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000013f69e39 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f3a889 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:10:48.780761 [ 3543 ] {a8ff606f-6e7e-4200-9365-aa91c92c97d0} 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]:56944) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000013f69e39 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f3a889 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:10:48.861110 [ 3543 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000013f69e39 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f3a889 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:10:49.482206 [ 3542 ] {c6a8f42f-55c9-438a-949a-30d57c90a71a} 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 0.0.0.0:0) (comment: 01292_optimize_data_skip_idx_order_by_expr.sql) (in query: /* ddl_entry=query-0000000002 */ CREATE TABLE test_5qle7tzs.data_01292 UUID 'e82eb30b-704a-49fe-a1b2-0b9221828abe' (`key` Int32, INDEX key_idx key TYPE minmax GRANULARITY 1) ENGINE = MergeTree ORDER BY key + 0 SETTINGS index_granularity = 20324, 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 = 149155383, compact_parts_max_granules_to_buffer = 104, compact_parts_merge_max_bytes_to_prefetch_part = 23787917, merge_max_block_size = 2982, old_parts_lifetime = 212., prefer_fetch_merged_part_size_threshold = 7436289908, 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 = 29592718, 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 = false, marks_compress_block_size = 91404, primary_key_compress_block_size = 52943, use_primary_key_cache = false, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda7a6 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000118cbf6e 8. /build/src/Storages/MergeTree/MergeTreeData.cpp:1922: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x0000000016238b3d 9. /build/src/Storages/StorageMergeTree.cpp:161: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000016556df5 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000165568d0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000165531fd 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ca1a22 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001481ee32 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 17. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 18. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 19. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 20. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 21. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 22. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 23. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 24. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:10:49.584649 [ 3542 ] {c6a8f42f-55c9-438a-949a-30d57c90a71a} 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]:57158) (comment: 01292_optimize_data_skip_idx_order_by_expr.sql) (query 2, line 3) (in query: CREATE TABLE data_01292 (`key` Int, INDEX key_idx key TYPE minmax GRANULARITY 1) ENGINE = MergeTree ORDER BY key + 0 SETTINGS index_granularity = 20324, 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 = 149155383, compact_parts_max_granules_to_buffer = 104, compact_parts_merge_max_bytes_to_prefetch_part = 23787917, merge_max_block_size = 2982, old_parts_lifetime = 212., prefer_fetch_merged_part_size_threshold = 7436289908, 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 = 29592718, 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 = false, marks_compress_block_size = 91404, primary_key_compress_block_size = 52943, use_primary_key_cache = false, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda7a6 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000118cbf6e 8. /build/src/Storages/MergeTree/MergeTreeData.cpp:1922: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x0000000016238b3d 9. /build/src/Storages/StorageMergeTree.cpp:161: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000016556df5 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000165568d0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000165531fd 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ca1a22 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001481ee32 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 17. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 18. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 19. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 20. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 21. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 22. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 23. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 24. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:10:49.610944 [ 3542 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda7a6 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000118cbf6e 8. /build/src/Storages/MergeTree/MergeTreeData.cpp:1922: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x0000000016238b3d 9. /build/src/Storages/StorageMergeTree.cpp:161: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000016556df5 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000165568d0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000165531fd 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ca1a22 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001481ee32 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 17. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 18. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 19. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 20. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 21. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 22. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 23. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 24. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:10:50.139958 [ 6168 ] {d02e16ec-8fb8-4b4b-a0f0-27e615660313} executeQuery: Code: 6. DB::Exception: Cannot parse string '2023-01-01' as Float64: syntax error at position 4 (parsed just '2023'). Note: there are toFloat64OrZero and toFloat64OrNull functions, which returns zero/NULL instead of throwing exception.: In scope SELECT CAST('2023-01-01', 'Float64'). (CANNOT_PARSE_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51756) (comment: 02900_issue_55858.sql) (query 2, line 3) (in query: select cast('2023-01-01' as Float64);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToFloat64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000012f477cb 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl, DB::detail::NameToFloat64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000012f4745e 6. /build/src/Functions/FunctionsConversion.h:2472: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToFloat64, 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::NameToFloat64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e91924 7. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToFloat64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eaa0ee 8. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToFloat64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ea991a 9. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 10. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Functions/IFunction.cpp:513: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c80999 14. /build/src/Functions/FunctionsConversion.h:3487: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000012ceb2d6 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012cc745b 16. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fc534a 17. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 18. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 19. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 20. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f75b 21. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 28. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 29. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 31. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 2025.07.13 02:10:50.147334 [ 6168 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2023-01-01' as Float64: syntax error at position 4 (parsed just '2023'). Note: there are toFloat64OrZero and toFloat64OrNull functions, which returns zero/NULL instead of throwing exception.: In scope SELECT CAST('2023-01-01', 'Float64'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToFloat64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000012f477cb 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl, DB::detail::NameToFloat64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000012f4745e 6. /build/src/Functions/FunctionsConversion.h:2472: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToFloat64, 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::NameToFloat64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e91924 7. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToFloat64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eaa0ee 8. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToFloat64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ea991a 9. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 10. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Functions/IFunction.cpp:513: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c80999 14. /build/src/Functions/FunctionsConversion.h:3487: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000012ceb2d6 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012cc745b 16. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fc534a 17. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 18. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 19. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 20. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f75b 21. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 28. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 29. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 31. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 2025.07.13 02:10:50.508146 [ 6168 ] {c11ebb50-8a56-4d46-ad79-5b2479b9dff4} executeQuery: Code: 6. DB::Exception: Cannot parse string '2023-01-01' as Float32: syntax error at position 4 (parsed just '2023'). Note: there are toFloat32OrZero and toFloat32OrNull functions, which returns zero/NULL instead of throwing exception.: In scope SELECT CAST('2023-01-01', 'Float32'). (CANNOT_PARSE_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51756) (comment: 02900_issue_55858.sql) (query 3, line 4) (in query: select cast('2023-01-01' as Float32);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToFloat32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000012f3e38b 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl, DB::detail::NameToFloat32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000012f3e01e 6. /build/src/Functions/FunctionsConversion.h:2472: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToFloat32, 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::NameToFloat32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e90b64 7. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToFloat32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ea8dce 8. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToFloat32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ea85fa 9. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 10. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Functions/IFunction.cpp:513: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c80999 14. /build/src/Functions/FunctionsConversion.h:3487: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000012ceb2d6 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012cc745b 16. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fc534a 17. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 18. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 19. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 20. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f75b 21. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 28. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 29. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 31. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 2025.07.13 02:10:50.609847 [ 6168 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2023-01-01' as Float32: syntax error at position 4 (parsed just '2023'). Note: there are toFloat32OrZero and toFloat32OrNull functions, which returns zero/NULL instead of throwing exception.: In scope SELECT CAST('2023-01-01', 'Float32'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToFloat32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000012f3e38b 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl, DB::detail::NameToFloat32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000012f3e01e 6. /build/src/Functions/FunctionsConversion.h:2472: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToFloat32, 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::NameToFloat32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e90b64 7. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToFloat32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ea8dce 8. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToFloat32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ea85fa 9. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 10. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Functions/IFunction.cpp:513: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c80999 14. /build/src/Functions/FunctionsConversion.h:3487: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000012ceb2d6 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012cc745b 16. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fc534a 17. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 18. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 19. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 20. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f75b 21. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 28. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 29. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 31. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 2025.07.13 02:10:50.943432 [ 6168 ] {be1d428a-d894-4b87-aea9-10fa5aa5966d} executeQuery: Code: 6. DB::Exception: Cannot parse string '2023-01-01' as Float32: syntax error at position 4 (parsed just '2023'). Note: there are toFloat32OrZero and toFloat32OrNull functions, which returns zero/NULL instead of throwing exception.: In scope SELECT toFloat32('2023-01-01'). (CANNOT_PARSE_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51756) (comment: 02900_issue_55858.sql) (query 4, line 5) (in query: select toFloat32('2023-01-01');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToFloat32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000012f3e38b 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl, DB::detail::NameToFloat32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000012f3e01e 6. /build/src/Functions/FunctionsConversion.h:2472: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToFloat32, 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::NameToFloat32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e90b64 7. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToFloat32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ea8dce 8. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToFloat32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ea85fa 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:10:50.964802 [ 6168 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2023-01-01' as Float32: syntax error at position 4 (parsed just '2023'). Note: there are toFloat32OrZero and toFloat32OrNull functions, which returns zero/NULL instead of throwing exception.: In scope SELECT toFloat32('2023-01-01'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToFloat32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000012f3e38b 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl, DB::detail::NameToFloat32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000012f3e01e 6. /build/src/Functions/FunctionsConversion.h:2472: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToFloat32, 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::NameToFloat32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e90b64 7. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToFloat32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ea8dce 8. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToFloat32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ea85fa 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:10:51.301164 [ 6168 ] {02b6f18e-e662-4934-91d7-05f79dbb603f} executeQuery: Code: 6. DB::Exception: Cannot parse string '2023-01-01' as Float64: syntax error at position 4 (parsed just '2023'). Note: there are toFloat64OrZero and toFloat64OrNull functions, which returns zero/NULL instead of throwing exception.: In scope SELECT toFloat64('2023-01-01'). (CANNOT_PARSE_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51756) (comment: 02900_issue_55858.sql) (query 5, line 6) (in query: select toFloat64('2023-01-01');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToFloat64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000012f477cb 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl, DB::detail::NameToFloat64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000012f4745e 6. /build/src/Functions/FunctionsConversion.h:2472: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToFloat64, 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::NameToFloat64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e91924 7. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToFloat64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eaa0ee 8. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToFloat64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ea991a 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:10:51.317308 [ 6168 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2023-01-01' as Float64: syntax error at position 4 (parsed just '2023'). Note: there are toFloat64OrZero and toFloat64OrNull functions, which returns zero/NULL instead of throwing exception.: In scope SELECT toFloat64('2023-01-01'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToFloat64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000012f477cb 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl, DB::detail::NameToFloat64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000012f4745e 6. /build/src/Functions/FunctionsConversion.h:2472: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToFloat64, 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::NameToFloat64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e91924 7. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToFloat64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eaa0ee 8. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToFloat64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ea991a 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:10:54.292898 [ 5121 ] {f4d8bd5b-26a6-42d4-8771-d3ed33aedf99} 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]:51900) (comment: 02025_storage_filelog_virtual_col.sh) (query 1, line 1) (in query: detach table file_log;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Databases/DatabaseReplicated.cpp:1106: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013cc3688 5. /build/src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc384b 6. /build/src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833287 7. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 8. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 9. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:10:54.332051 [ 5121 ] {} TCPHandler: Code: 80. DB::Exception: DETACH TABLE is not allowed for Replicated databases. Use DETACH TABLE PERMANENTLY or SYSTEM RESTART REPLICA or set database_replicated_always_detach_permanently to 1. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Databases/DatabaseReplicated.cpp:1106: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013cc3688 5. /build/src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc384b 6. /build/src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833287 7. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 8. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 9. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:10:55.050607 [ 6619 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778c58 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168167bf 10. /build/src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000001680ff45 11. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:10:55.057316 [ 6619 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x0000000016810069 5. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 6. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 2025.07.13 02:10:55.550974 [ 5117 ] {51bb3f1f-570c-45f9-91f0-3ace5a2023b4} executeQuery: Code: 60. DB::Exception: Table test_00x89560.ghdata does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51962) (comment: 03272_ghdata_object_to_json_alter_shared_data.sh) (query 1, line 1) (in query: INSERT INTO ghdata FORMAT JSONAsObject), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013cf9b5f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144148c9 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001441ace8 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001484a2e4 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014851d18 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:10:55.580860 [ 5117 ] {} TCPHandler: Code: 60. DB::Exception: Table test_00x89560.ghdata does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013cf9b5f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144148c9 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001441ace8 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001484a2e4 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014851d18 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:10:56.080801 [ 6619 ] {15363e50-a78f-4c9d-95e8-95aa25b9884b} executeQuery: Code: 60. DB::Exception: Table test_00x89560.ghdata does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51986) (comment: 03272_ghdata_object_to_json_alter_shared_data.sh) (query 1, line 1) (in query: ALTER TABLE ghdata MODIFY column data JSON(max_dynamic_paths=8) SETTINGS mutations_sync=1), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013cf9b5f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144148c9 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001441ace8 7. /build/src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x0000000013cd7e42 8. /build/src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013cd7a7f 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fbcf4 10. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:10:56.107886 [ 6619 ] {} TCPHandler: Code: 60. DB::Exception: Table test_00x89560.ghdata does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013cf9b5f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144148c9 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001441ace8 7. /build/src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x0000000013cd7e42 8. /build/src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013cd7a7f 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fbcf4 10. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:10:56.646680 [ 6619 ] {b3ba66e3-6d4d-4572-8d02-e52eb01c2349} 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]:52000) (comment: 03272_ghdata_object_to_json_alter_shared_data.sh) (query 1, line 1) (in query: SELECT count() FROM ghdata WHERE NOT ignore(*)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f633d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:10:56.685765 [ 6619 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'ghdata' in scope SELECT count() FROM ghdata WHERE NOT ignore(*). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f633d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:10:57.186823 [ 3543 ] {6bd915e9-f200-4b00-9a8a-f8fcc4804d77} 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]:52016) (comment: 03272_ghdata_object_to_json_alter_shared_data.sh) (query 1, line 1) (in query: SELECT data.repo.name, count() AS stars FROM ghdata WHERE data.type = 'WatchEvent' GROUP BY data.repo.name ORDER BY stars DESC, data.repo.name LIMIT 5), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f633d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:10:57.232842 [ 3543 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'ghdata' in scope SELECT data.repo.name, count() AS stars FROM ghdata WHERE data.type = 'WatchEvent' GROUP BY data.repo.name ORDER BY stars DESC, data.repo.name ASC LIMIT 5. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f633d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:10:57.804708 [ 16763 ] {07e6e906-2fdc-4657-a8c8-e54c67c4f284} 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]:52034) (comment: 03272_ghdata_object_to_json_alter_shared_data.sh) (query 1, line 1) (in query: SELECT data.payload.commits[].author.name AS name, count() AS c FROM ghdata ARRAY JOIN data.payload.commits[].author.name GROUP BY name ORDER BY c DESC, name LIMIT 5), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f633d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:10:57.835074 [ 16763 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'ghdata' in scope SELECT data.payload.commits.:`Array(JSON)`.author.name AS name, count() AS c FROM ghdata ARRAY JOIN data.payload.commits.:`Array(JSON)`.author.name GROUP BY name ORDER BY c DESC, name ASC LIMIT 5. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f633d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:10:58.158423 [ 16784 ] {a924018c-1a55-44d2-9ae0-dcb765a4855b} executeQuery: Code: 43. DB::Exception: Cannot reinterpret String as FixedString because it is not fixed size and contiguous in memory: In scope SELECT reinterpret('123', 'FixedString(1)'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57108) (comment: 01676_reinterpret_as.sql) (query 42, line 42) (in query: SELECT reinterpret('123', 'FixedString(1)');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/reinterpretAs.cpp:85: DB::(anonymous namespace)::FunctionReinterpret::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e4e7a6a 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:10:58.167107 [ 16784 ] {} TCPHandler: Code: 43. DB::Exception: Cannot reinterpret String as FixedString because it is not fixed size and contiguous in memory: In scope SELECT reinterpret('123', 'FixedString(1)'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/reinterpretAs.cpp:85: DB::(anonymous namespace)::FunctionReinterpret::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e4e7a6a 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:10:58.247262 [ 3543 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000013779f8b 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000137794b8 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778bc3 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678d325 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:10:58.455835 [ 6168 ] {9d056fe2-f3e8-4592-8613-0255499e60a0} 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]:52052) (comment: 03272_ghdata_object_to_json_alter_shared_data.sh) (query 1, line 1) (in query: SELECT max(data.payload.pull_request.assignees[].size0) FROM ghdata), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f633d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:10:58.499350 [ 6168 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'ghdata' in scope SELECT max(data.payload.pull_request.assignees.:`Array(JSON)`.size0) FROM ghdata. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f633d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:10:59.106630 [ 3543 ] {a1d7d3fb-7f70-4a06-a74e-7caa733befe2} 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]:52058) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.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&) @ 0x0000000013b5c099 4. /build/src/IO/readDecimalText.h:163: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x0000000013b5a6a1 5. /build/src/DataTypes/Serializations/SerializationDecimal.cpp:46: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x0000000013bb680d 6. /build/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) @ 0x0000000012ffbc81 7. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x0000000012ffb99e 8. /build/src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x0000000012fea844 9. /build/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&&) @ 0x0000000012e97aa1 10. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eb8d8e 11. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eb85ba 12. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 13. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 14. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 15. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 16. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 17. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 18. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 25. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 26. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 31. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 2025.07.13 02:10:59.113819 [ 3543 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.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&) @ 0x0000000013b5c099 4. /build/src/IO/readDecimalText.h:163: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x0000000013b5a6a1 5. /build/src/DataTypes/Serializations/SerializationDecimal.cpp:46: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x0000000013bb680d 6. /build/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) @ 0x0000000012ffbc81 7. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x0000000012ffb99e 8. /build/src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x0000000012fea844 9. /build/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&&) @ 0x0000000012e97aa1 10. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eb8d8e 11. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eb85ba 12. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 13. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 14. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 15. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 16. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 17. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 18. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 25. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 26. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 31. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 2025.07.13 02:10:59.314044 [ 3543 ] {6a27bf01-a107-41a2-bf2d-94ab656d3766} 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]:52058) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.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&) @ 0x0000000013b5c099 4. /build/src/IO/readDecimalText.h:163: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x0000000013b5a6a1 5. /build/src/DataTypes/Serializations/SerializationDecimal.cpp:46: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x0000000013bb680d 6. /build/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) @ 0x0000000012ffbc81 7. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x0000000012ffb99e 8. /build/src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x0000000012fea844 9. /build/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&&) @ 0x0000000012e97aa1 10. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eb8d8e 11. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eb85ba 12. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 13. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 14. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 15. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 16. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 17. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 18. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 25. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 26. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 31. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 2025.07.13 02:10:59.323046 [ 3543 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.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&) @ 0x0000000013b5c099 4. /build/src/IO/readDecimalText.h:163: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x0000000013b5a6a1 5. /build/src/DataTypes/Serializations/SerializationDecimal.cpp:46: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x0000000013bb680d 6. /build/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) @ 0x0000000012ffbc81 7. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x0000000012ffb99e 8. /build/src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x0000000012fea844 9. /build/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&&) @ 0x0000000012e97aa1 10. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eb8d8e 11. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eb85ba 12. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 13. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 14. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 15. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 16. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 17. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 18. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 25. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 26. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 31. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 2025.07.13 02:11:00.042572 [ 5121 ] {63895fbc-6907-4180-a555-341855ae0c75} executeQuery: Code: 59. DB::Exception: Invalid sampling column type in storage parameters: UUID. Must be one unsigned integer type. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53218) (comment: 01942_create_table_with_sample.sql) (query 1, line 1) (in query: CREATE TABLE IF NOT EXISTS sample_incorrect (`x` UUID) ENGINE = MergeTree ORDER BY tuple(x) SAMPLE BY x SETTINGS index_granularity = 33306, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.8725109100341797, replace_long_file_name_to_hash = false, max_file_name_length = 71, min_bytes_for_full_part_storage = 58842570, compact_parts_max_bytes_to_buffer = 332862504, compact_parts_max_granules_to_buffer = 69, compact_parts_merge_max_bytes_to_prefetch_part = 22179218, merge_max_block_size = 11077, old_parts_lifetime = 22., prefer_fetch_merged_part_size_threshold = 9927200335, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 5460071205, index_granularity_bytes = 24807606, 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 = true, marks_compress_block_size = 42007, primary_key_compress_block_size = 22393, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:344: DB::checkSampleExpression(DB::StorageInMemoryMetadata const&, bool, bool) @ 0x0000000016227a26 5. /build/src/Storages/MergeTree/MergeTreeData.cpp:525: 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) @ 0x00000000162253c1 6. /build/src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000016556b75 7. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000165568d0 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000165531fd 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ca1a22 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001481ee32 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:11:00.051498 [ 5121 ] {} TCPHandler: Code: 59. DB::Exception: Invalid sampling column type in storage parameters: UUID. Must be one unsigned integer type. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:344: DB::checkSampleExpression(DB::StorageInMemoryMetadata const&, bool, bool) @ 0x0000000016227a26 5. /build/src/Storages/MergeTree/MergeTreeData.cpp:525: 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) @ 0x00000000162253c1 6. /build/src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000016556b75 7. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000165568d0 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000165531fd 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ca1a22 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001481ee32 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:11:00.836498 [ 3543 ] {4f218d1b-d952-47e9-beab-220e4c9eed6a} 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]:52058) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000009fb386b 4. /build/src/DataTypes/DataTypeDecimalBase.h:77: DB::DataTypeDecimalBase>::DataTypeDecimalBase(unsigned int, unsigned int) @ 0x0000000013b02545 5. /build/src/DataTypes/DataTypesDecimal.h:39: std::shared_ptr>> std::allocate_shared[abi:se190107]>, std::allocator>>, unsigned long const&, unsigned long&, 0>(std::allocator>> const&, unsigned long const&, unsigned long&) @ 0x0000000013b5bb66 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr DB::createDecimalMaxPrecision>(unsigned long) @ 0x0000000013b5a1ff 7. /build/src/Functions/FunctionsConversion.h:2245: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x0000000012eb83eb 8. /build/src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012eb8255 9. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 10. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 11. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:11:00.860692 [ 3543 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000009fb386b 4. /build/src/DataTypes/DataTypeDecimalBase.h:77: DB::DataTypeDecimalBase>::DataTypeDecimalBase(unsigned int, unsigned int) @ 0x0000000013b02545 5. /build/src/DataTypes/DataTypesDecimal.h:39: std::shared_ptr>> std::allocate_shared[abi:se190107]>, std::allocator>>, unsigned long const&, unsigned long&, 0>(std::allocator>> const&, unsigned long const&, unsigned long&) @ 0x0000000013b5bb66 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr DB::createDecimalMaxPrecision>(unsigned long) @ 0x0000000013b5a1ff 7. /build/src/Functions/FunctionsConversion.h:2245: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x0000000012eb83eb 8. /build/src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012eb8255 9. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 10. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 11. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:11:01.015757 [ 3543 ] {bc0af664-7de7-4f5b-94ec-2f23bd5b6f65} 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]:52058) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000009fb386b 4. /build/src/DataTypes/DataTypeDecimalBase.h:77: DB::DataTypeDecimalBase>::DataTypeDecimalBase(unsigned int, unsigned int) @ 0x0000000013b02545 5. /build/src/DataTypes/DataTypesDecimal.h:39: std::shared_ptr>> std::allocate_shared[abi:se190107]>, std::allocator>>, unsigned long const&, unsigned long&, 0>(std::allocator>> const&, unsigned long const&, unsigned long&) @ 0x0000000013b5bb66 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr DB::createDecimalMaxPrecision>(unsigned long) @ 0x0000000013b5a1ff 7. /build/src/Functions/FunctionsConversion.h:2245: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x0000000012eb83eb 8. /build/src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012eb8255 9. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 10. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 11. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:11:01.032926 [ 3543 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000009fb386b 4. /build/src/DataTypes/DataTypeDecimalBase.h:77: DB::DataTypeDecimalBase>::DataTypeDecimalBase(unsigned int, unsigned int) @ 0x0000000013b02545 5. /build/src/DataTypes/DataTypesDecimal.h:39: std::shared_ptr>> std::allocate_shared[abi:se190107]>, std::allocator>>, unsigned long const&, unsigned long&, 0>(std::allocator>> const&, unsigned long const&, unsigned long&) @ 0x0000000013b5bb66 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr DB::createDecimalMaxPrecision>(unsigned long) @ 0x0000000013b5a1ff 7. /build/src/Functions/FunctionsConversion.h:2245: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x0000000012eb83eb 8. /build/src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012eb8255 9. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 10. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 11. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:11:01.036325 [ 3552 ] {} CgroupsReader: Cannot find 'kernel' in '/sys/fs/cgroup/memory.stat' (skipped 5489 similar messages) 2025.07.13 02:11:03.594050 [ 6532 ] {a4d203b2-b579-4a0a-a4e9-483fb1f1a53d} executeQuery: Code: 43. DB::Exception: Illegal type Float64 of argument 1 of function s2CapContains. Must be UInt64: In scope SELECT s2CapContains(nan, 3.14, 1157339245694594829). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53320) (comment: 01854_s2_cap_contains.sql) (query 4, line 8) (in query: select s2CapContains(nan, 3.14, 1157339245694594829);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000009fbd84b 4. /build/src/Functions/s2CapContains.cpp:76: DB::(anonymous namespace)::FunctionS2CapContains::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000e580da4 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:11:03.608667 [ 6532 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Float64 of argument 1 of function s2CapContains. Must be UInt64: In scope SELECT s2CapContains(nan, 3.14, 1157339245694594829). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000009fbd84b 4. /build/src/Functions/s2CapContains.cpp:76: DB::(anonymous namespace)::FunctionS2CapContains::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000e580da4 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:11:03.875777 [ 6532 ] {3d724fc1-5575-41f5-896c-d3c04e1da3c2} executeQuery: Code: 43. DB::Exception: Radius of the cap must not be nan in function s2CapContains: In scope SELECT s2CapContains(1157339245694594829, nan, 1157339245694594829). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53320) (comment: 01854_s2_cap_contains.sql) (query 5, line 9) (in query: select s2CapContains(1157339245694594829, nan, 1157339245694594829);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/s2CapContains.cpp:139: DB::(anonymous namespace)::FunctionS2CapContains::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e5807cf 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:11:03.893824 [ 6532 ] {} TCPHandler: Code: 43. DB::Exception: Radius of the cap must not be nan in function s2CapContains: In scope SELECT s2CapContains(1157339245694594829, nan, 1157339245694594829). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/s2CapContains.cpp:139: DB::(anonymous namespace)::FunctionS2CapContains::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e5807cf 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:11:04.033831 [ 6532 ] {d107f601-537c-47d4-9e20-18758e0a74ad} executeQuery: Code: 43. DB::Exception: Illegal type Float64 of argument 3 of function s2CapContains. Must be UInt64: In scope SELECT s2CapContains(1157339245694594829, 3.14, nan). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53320) (comment: 01854_s2_cap_contains.sql) (query 6, line 10) (in query: select s2CapContains(1157339245694594829, 3.14, nan);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000009fbd84b 4. /build/src/Functions/s2CapContains.cpp:76: DB::(anonymous namespace)::FunctionS2CapContains::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000e580da4 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:11:04.049577 [ 6532 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Float64 of argument 3 of function s2CapContains. Must be UInt64: In scope SELECT s2CapContains(1157339245694594829, 3.14, nan). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000009fbd84b 4. /build/src/Functions/s2CapContains.cpp:76: DB::(anonymous namespace)::FunctionS2CapContains::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000e580da4 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:11:04.317013 [ 6532 ] {0e3332f3-631b-49aa-ab9a-42d6ed164348} executeQuery: Code: 36. DB::Exception: Center (id 18446744073709551615) is not valid in function s2CapContains: In scope SELECT s2CapContains(toUInt64(-1), -1., toUInt64(-1)). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53320) (comment: 01854_s2_cap_contains.sql) (query 7, line 13) (in query: select s2CapContains(toUInt64(-1), -1.0, toUInt64(-1));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000000b831f0b 4. /build/src/Functions/s2CapContains.cpp:145: DB::(anonymous namespace)::FunctionS2CapContains::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e580691 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:11:04.394876 [ 6532 ] {} TCPHandler: Code: 36. DB::Exception: Center (id 18446744073709551615) is not valid in function s2CapContains: In scope SELECT s2CapContains(toUInt64(-1), -1., toUInt64(-1)). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000000b831f0b 4. /build/src/Functions/s2CapContains.cpp:145: DB::(anonymous namespace)::FunctionS2CapContains::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e580691 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:11:04.530495 [ 6532 ] {a605719d-8e56-49d1-bafe-1c87d524aa11} executeQuery: Code: 36. DB::Exception: Center (id 18446744073709551615) is not valid in function s2CapContains: In scope SELECT s2CapContains(toUInt64(-1), 9999.9999, toUInt64(-1)). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53320) (comment: 01854_s2_cap_contains.sql) (query 8, line 14) (in query: select s2CapContains(toUInt64(-1), 9999.9999, toUInt64(-1));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000000b831f0b 4. /build/src/Functions/s2CapContains.cpp:145: DB::(anonymous namespace)::FunctionS2CapContains::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e580691 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:11:04.543842 [ 6532 ] {} TCPHandler: Code: 36. DB::Exception: Center (id 18446744073709551615) is not valid in function s2CapContains: In scope SELECT s2CapContains(toUInt64(-1), 9999.9999, toUInt64(-1)). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000000b831f0b 4. /build/src/Functions/s2CapContains.cpp:145: DB::(anonymous namespace)::FunctionS2CapContains::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e580691 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:11:05.755553 [ 5117 ] {76730c26-37a2-4b48-921c-77438b70b092} 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]:53534) (comment: 02317_distinct_in_order_optimization_explain.sh) (query 1, line 1) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:11:05.800822 [ 5117 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:11:06.405722 [ 27539 ] {9cc50ea8-78fd-4dbe-8f3e-e4e0ec4e93f6} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=851, jobs=798). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53456) (comment: 02124_buffer_insert_select_race.sh) (in query: INSERT INTO t_buffer_string SELECT number::String from numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbdd1d3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd751c 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 7. /build/src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x00000000168cf907 8. /build/src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000001680710e 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:11:06.425389 [ 27539 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=851, jobs=798). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbdd1d3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd751c 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 7. /build/src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x00000000168cf907 8. /build/src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000001680710e 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:11:06.507296 [ 4871 ] {3f435dd8-578a-4b6a-8d44-39a5738be6bb} executeQuery: Code: 159. DB::Exception: Timeout exceeded (180 s) while flushing system log 'DB::SystemLogQueue'. (TIMEOUT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53704) (comment: 03020_long_values_pretty_are_not_cut_if_single.sh) (query 1, line 1) (in query: SYSTEM FLUSH LOGS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Common/SystemLogBase.cpp:168: DB::SystemLogQueue::waitFlush(long, bool) @ 0x000000000fbee407 5. /build/src/Interpreters/SystemLog.cpp:437: DB::SystemLogs::flush(bool, std::vector> const&) @ 0x0000000014a1ea9f 6. /build/src/Interpreters/InterpreterSystemQuery.cpp:796: DB::InterpreterSystemQuery::execute() @ 0x0000000014bd5a4e 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:11:06.511733 [ 27693 ] {cd49f768-d192-4640-b8e2-9afdb3af0c4f} 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]:53558) (comment: 02317_distinct_in_order_optimization_explain.sh) (query 1, line 1) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:11:06.520653 [ 4871 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded (180 s) while flushing system log 'DB::SystemLogQueue'. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Common/SystemLogBase.cpp:168: DB::SystemLogQueue::waitFlush(long, bool) @ 0x000000000fbee407 5. /build/src/Interpreters/SystemLog.cpp:437: DB::SystemLogs::flush(bool, std::vector> const&) @ 0x0000000014a1ea9f 6. /build/src/Interpreters/InterpreterSystemQuery.cpp:796: DB::InterpreterSystemQuery::execute() @ 0x0000000014bd5a4e 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:11:06.538244 [ 27693 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:11:06.677591 [ 6168 ] {562d0b8f-90e5-4f80-84fc-e275eb19b799} executeQuery: Code: 53. DB::Exception: CAST AS Array can only be performed between same-dimensional Array, Map or String types: While processing _CAST(a, 'Array(String)') AS a. (TYPE_MISMATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53510) (comment: 01732_alters_bad_conversions.sql) (query 5, line 6) (in query: ALTER TABLE bad_conversions MODIFY COLUMN a Array(String);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/FunctionsConversion.h:3886: DB::detail::FunctionCast::createArrayWrapper(std::shared_ptr const&, DB::DataTypeArray const&) const @ 0x0000000012cd98fb 5. /build/src/Functions/FunctionsConversion.h:6098: DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000012cd8cbb 6. /build/src/Functions/FunctionsConversion.h:5819: DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000012cc817b 7. /build/src/Functions/FunctionsConversion.h:5746: DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000012cc6f09 8. /build/src/Functions/FunctionsConversion.h:3444: DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x0000000012cc67f0 9. /build/src/Interpreters/ActionsDAG.cpp:403: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x0000000013eba709 10. /build/src/Interpreters/ActionsDAG.cpp:330: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x0000000013eb9e43 11. /build/src/Interpreters/ActionsVisitor.cpp:697: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000014477251 12. /build/src/Interpreters/ActionsMatcher.h:178: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000014484aaf 13. /build/src/Interpreters/ActionsVisitor.cpp:1366: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000014479512 14. /build/src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000001446f1d5 15. /build/src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x000000001444cf68 16. /build/src/Interpreters/ExpressionAnalyzer.cpp:1867: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x000000001445c216 17. /build/src/Interpreters/inplaceBlockConversions.cpp:172: DB::(anonymous namespace)::createExpressions(DB::Block const&, std::shared_ptr, bool, std::shared_ptr) @ 0x0000000014bbf56c 18. /build/src/Interpreters/inplaceBlockConversions.cpp:184: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000014bbefba 19. /build/src/Storages/MergeTree/MergeTreeData.cpp:3866: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001625a9ea 20. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd033 21. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 22. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:11:06.701273 [ 6168 ] {} TCPHandler: Code: 53. DB::Exception: CAST AS Array can only be performed between same-dimensional Array, Map or String types: While processing _CAST(a, 'Array(String)') AS a. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/FunctionsConversion.h:3886: DB::detail::FunctionCast::createArrayWrapper(std::shared_ptr const&, DB::DataTypeArray const&) const @ 0x0000000012cd98fb 5. /build/src/Functions/FunctionsConversion.h:6098: DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000012cd8cbb 6. /build/src/Functions/FunctionsConversion.h:5819: DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000012cc817b 7. /build/src/Functions/FunctionsConversion.h:5746: DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000012cc6f09 8. /build/src/Functions/FunctionsConversion.h:3444: DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x0000000012cc67f0 9. /build/src/Interpreters/ActionsDAG.cpp:403: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x0000000013eba709 10. /build/src/Interpreters/ActionsDAG.cpp:330: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x0000000013eb9e43 11. /build/src/Interpreters/ActionsVisitor.cpp:697: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000014477251 12. /build/src/Interpreters/ActionsMatcher.h:178: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000014484aaf 13. /build/src/Interpreters/ActionsVisitor.cpp:1366: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000014479512 14. /build/src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000001446f1d5 15. /build/src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x000000001444cf68 16. /build/src/Interpreters/ExpressionAnalyzer.cpp:1867: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x000000001445c216 17. /build/src/Interpreters/inplaceBlockConversions.cpp:172: DB::(anonymous namespace)::createExpressions(DB::Block const&, std::shared_ptr, bool, std::shared_ptr) @ 0x0000000014bbf56c 18. /build/src/Interpreters/inplaceBlockConversions.cpp:184: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000014bbefba 19. /build/src/Storages/MergeTree/MergeTreeData.cpp:3866: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001625a9ea 20. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd033 21. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 22. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:11:07.152057 [ 16763 ] {fba20188-1d6b-4d7f-8861-89cf27f9ebf1} 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]:53584) (comment: 02317_distinct_in_order_optimization_explain.sh) (query 1, line 1) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:11:07.200265 [ 16763 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:11:07.733026 [ 27539 ] {6012aa36-d49d-4d0a-9798-87479984b925} 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]:53592) (comment: 02317_distinct_in_order_optimization_explain.sh) (query 1, line 1) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:11:07.779468 [ 27539 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:11:07.920076 [ 27693 ] {7a23b0be-c474-4a86-a622-aea54f244272} 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]:53606) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:11:07.955717 [ 27693 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:11:08.290020 [ 27539 ] {83e31546-070e-4f0a-a070-34c4bccd8e67} 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]:53612) (comment: 02317_distinct_in_order_optimization_explain.sh) (query 1, line 1) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:11:08.365414 [ 27539 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:11:08.429725 [ 6532 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000013779f8b 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000137794b8 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778bc3 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678d325 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:11:08.768618 [ 5998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778c58 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168167bf 10. /build/src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000001680ff45 11. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:11:08.770313 [ 5998 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x0000000016810069 5. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 6. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 2025.07.13 02:11:08.880441 [ 16763 ] {ef115f8e-a7d2-4471-860b-8f06bae10bb8} 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]:53640) (comment: 02317_distinct_in_order_optimization_explain.sh) (query 1, line 1) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:11:08.923974 [ 16763 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:11:08.983291 [ 6168 ] {004c664a-751e-44fd-89b1-3751bf499b5d} executeQuery: Code: 70. DB::Exception: Enum conversion changes value for element 'foo' from 1 to 2: While processing _CAST(e, 'Enum8(\'bar\' = 1, \'foo\' = 2)') AS e. (CANNOT_CONVERT_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53510) (comment: 01732_alters_bad_conversions.sql) (query 10, line 12) (in query: ALTER TABLE bad_conversions_2 MODIFY COLUMN e Enum('bar' = 1, 'foo' = 2);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x00000000108a142b 4. /build/src/Functions/FunctionsConversion.h:5578: _ZNK2DB6detail12FunctionCast25checkEnumToEnumConversionINS_12DataTypeEnumIDB8_EES5_EEvPKT_PKT0_ @ 0x0000000012e5e7bb 5. /build/src/Functions/FunctionsConversion.h:5535: std::function::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createEnumWrapper<_BitInt(8)>(DB::ColumnNullable, DB::DataTypeEnum<_BitInt(8)> const*) const @ 0x0000000012e5e325 6. /build/src/Functions/FunctionsConversion.h:5945: DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000012cd829e 7. /build/src/Functions/FunctionsConversion.h:5819: DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000012cc817b 8. /build/src/Functions/FunctionsConversion.h:5746: DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000012cc6f09 9. /build/src/Functions/FunctionsConversion.h:3444: DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x0000000012cc67f0 10. /build/src/Interpreters/ActionsDAG.cpp:403: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x0000000013eba709 11. /build/src/Interpreters/ActionsDAG.cpp:330: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x0000000013eb9e43 12. /build/src/Interpreters/ActionsVisitor.cpp:697: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000014477251 13. /build/src/Interpreters/ActionsMatcher.h:178: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000014484aaf 14. /build/src/Interpreters/ActionsVisitor.cpp:1366: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000014479512 15. /build/src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000001446f1d5 16. /build/src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x000000001444cf68 17. /build/src/Interpreters/ExpressionAnalyzer.cpp:1867: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x000000001445c216 18. /build/src/Interpreters/inplaceBlockConversions.cpp:172: DB::(anonymous namespace)::createExpressions(DB::Block const&, std::shared_ptr, bool, std::shared_ptr) @ 0x0000000014bbf56c 19. /build/src/Interpreters/inplaceBlockConversions.cpp:184: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000014bbefba 20. /build/src/Storages/MergeTree/MergeTreeData.cpp:3866: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001625a9ea 21. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd033 22. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 23. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 25. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 26. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 31. ? @ 0x00007f7210eb6ac3 2025.07.13 02:11:08.996172 [ 6168 ] {} TCPHandler: Code: 70. DB::Exception: Enum conversion changes value for element 'foo' from 1 to 2: While processing _CAST(e, 'Enum8(\'bar\' = 1, \'foo\' = 2)') AS e. (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x00000000108a142b 4. /build/src/Functions/FunctionsConversion.h:5578: _ZNK2DB6detail12FunctionCast25checkEnumToEnumConversionINS_12DataTypeEnumIDB8_EES5_EEvPKT_PKT0_ @ 0x0000000012e5e7bb 5. /build/src/Functions/FunctionsConversion.h:5535: std::function::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createEnumWrapper<_BitInt(8)>(DB::ColumnNullable, DB::DataTypeEnum<_BitInt(8)> const*) const @ 0x0000000012e5e325 6. /build/src/Functions/FunctionsConversion.h:5945: DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000012cd829e 7. /build/src/Functions/FunctionsConversion.h:5819: DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000012cc817b 8. /build/src/Functions/FunctionsConversion.h:5746: DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000012cc6f09 9. /build/src/Functions/FunctionsConversion.h:3444: DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x0000000012cc67f0 10. /build/src/Interpreters/ActionsDAG.cpp:403: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x0000000013eba709 11. /build/src/Interpreters/ActionsDAG.cpp:330: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x0000000013eb9e43 12. /build/src/Interpreters/ActionsVisitor.cpp:697: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000014477251 13. /build/src/Interpreters/ActionsMatcher.h:178: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000014484aaf 14. /build/src/Interpreters/ActionsVisitor.cpp:1366: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000014479512 15. /build/src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000001446f1d5 16. /build/src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x000000001444cf68 17. /build/src/Interpreters/ExpressionAnalyzer.cpp:1867: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x000000001445c216 18. /build/src/Interpreters/inplaceBlockConversions.cpp:172: DB::(anonymous namespace)::createExpressions(DB::Block const&, std::shared_ptr, bool, std::shared_ptr) @ 0x0000000014bbf56c 19. /build/src/Interpreters/inplaceBlockConversions.cpp:184: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000014bbefba 20. /build/src/Storages/MergeTree/MergeTreeData.cpp:3866: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001625a9ea 21. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd033 22. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 23. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 25. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 26. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 31. ? @ 0x00007f7210eb6ac3 2025.07.13 02:11:09.194082 [ 27693 ] {327fa829-552d-4704-9b30-dde87304a967} executeQuery: Code: 60. DB::Exception: Table test_3gli03ef.t_json_nested does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37260) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013cf9b5f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144148c9 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001441ace8 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001484a2e4 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014851d18 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:11:09.244356 [ 27693 ] {} TCPHandler: Code: 60. DB::Exception: Table test_3gli03ef.t_json_nested does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013cf9b5f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144148c9 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001441ace8 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001484a2e4 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014851d18 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:11:09.441115 [ 16763 ] {5789fde8-d55e-4979-a276-da4750bed3a6} 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]:37266) (comment: 02317_distinct_in_order_optimization_explain.sh) (query 1, line 1) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:11:09.473824 [ 16763 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:11:09.872629 [ 27539 ] {e2c4db2d-50e8-4756-8778-1f56eb5cbbec} executeQuery: Code: 60. DB::Exception: Table test_3gli03ef.t_json_nested does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37274) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013cf9b5f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144148c9 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001441ace8 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001484a2e4 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014851d18 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:11:09.917374 [ 27539 ] {} TCPHandler: Code: 60. DB::Exception: Table test_3gli03ef.t_json_nested does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013cf9b5f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144148c9 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001441ace8 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001484a2e4 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014851d18 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:11:10.354272 [ 4930 ] {b01b4746-d897-45b1-bceb-c75ceafa40a0} 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]:37292) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f633d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:11:10.389700 [ 4930 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f633d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:11:10.930021 [ 27539 ] {74b7bbbd-4d99-41bf-a1ad-87d767a2c1f4} 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]:37310) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f633d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:11:10.981529 [ 27539 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f633d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:11:11.614119 [ 27539 ] {a996413d-d9d5-4b76-bf5a-017a1a9f8b7f} 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]:37326) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f633d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:11:11.631101 [ 27539 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f633d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:11:12.125119 [ 6168 ] {bbb6d483-2f9a-49cd-a415-da249dbe20e6} 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]:37342) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f633d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:11:12.170051 [ 6168 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f633d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:11:12.365595 [ 4870 ] {69c05be0-1434-4c49-a1ff-3bac5e31e541} executeQuery: Code: 289. DB::Exception: Replica doesn't have part '20181115_0_0_0' which was successfully written to quorum of other replicas. Send query to another replica or disable 'select_sequential_consistency' setting. (REPLICA_IS_NOT_IN_QUORUM) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51866) (comment: 02377_majority_insert_quorum_zookeeper_long.sql) (query 24, line 43) (in query: SELECT x FROM quorum3 ORDER BY x;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:5755: DB::StorageReplicatedMergeTree::getMaxAddedBlocks() const @ 0x0000000015e3e1b1 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:5834: DB::StorageReplicatedMergeTree::readLocalSequentialConsistencyImpl(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, unsigned long, unsigned long) @ 0x0000000015e3ee30 6. /build/src/Storages/StorageReplicatedMergeTree.cpp:5786: DB::StorageReplicatedMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000015e3e70c 7. /build/src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000148b600e 8. /build/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&) @ 0x00000000148ad029 9. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 10. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 12. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 14. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 15. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 20. ? @ 0x00007f7210eb6ac3 21. ? @ 0x00007f7210f48850 2025.07.13 02:11:12.373702 [ 4870 ] {} TCPHandler: Code: 289. DB::Exception: Replica doesn't have part '20181115_0_0_0' which was successfully written to quorum of other replicas. Send query to another replica or disable 'select_sequential_consistency' setting. (REPLICA_IS_NOT_IN_QUORUM), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:5755: DB::StorageReplicatedMergeTree::getMaxAddedBlocks() const @ 0x0000000015e3e1b1 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:5834: DB::StorageReplicatedMergeTree::readLocalSequentialConsistencyImpl(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, unsigned long, unsigned long) @ 0x0000000015e3ee30 6. /build/src/Storages/StorageReplicatedMergeTree.cpp:5786: DB::StorageReplicatedMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000015e3e70c 7. /build/src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000148b600e 8. /build/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&) @ 0x00000000148ad029 9. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 10. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 12. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 14. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 15. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 20. ? @ 0x00007f7210eb6ac3 21. ? @ 0x00007f7210f48850 2025.07.13 02:11:12.789361 [ 6611 ] {6749a57d-ecc5-44f5-aef9-158db2103822} 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]:37370) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f633d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:11:12.869357 [ 6611 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f633d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:11:13.197299 [ 3542 ] {c2547337-d510-4fcd-b159-c0d4b6515144} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37398) (comment: 02124_buffer_insert_select_race.sh) (query 1, line 1) (in query: DROP TABLE t_buffer_string), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/IStorage.cpp:171: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015c3ce9a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833683 6. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 7. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:11:13.243536 [ 3542 ] {} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/IStorage.cpp:171: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015c3ce9a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833683 6. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 7. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:11:13.273317 [ 16756 ] {37494797-d517-4198-ad72-d85ef8457601} executeQuery: Code: 48. DB::Exception: MergeJoinAlgorithm does not implement ASOF Right join. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53230) (comment: 03149_asof_join_ddb_timestamps.sql) (query 15, line 66) (in query: SELECT p.begin, e.value FROM probe0 p ASOF RIGHT JOIN events0 e ON p.begin >= e.begin ORDER BY e.begin ASC;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::JoinKind&) @ 0x0000000016b4c50b 4. /build/src/Processors/Transforms/MergeJoinTransform.cpp:451: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(DB::JoinKind, DB::JoinStrictness, DB::TableJoin::JoinOnClause const&, std::vector> const&, unsigned long) @ 0x0000000016b44f97 5. /build/src/Processors/Transforms/MergeJoinTransform.cpp:470: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(std::shared_ptr, std::vector> const&, unsigned long) @ 0x0000000016b4532c 6. /build/src/Processors/Merges/IMergingTransform.h:112: DB::MergeJoinTransform::MergeJoinTransform(std::shared_ptr, std::vector> const&, DB::Block const&, unsigned long, unsigned long) @ 0x0000000016b4bab5 7. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::QueryPipelineBuilder::joinPipelinesYShaped(std::unique_ptr>, std::unique_ptr>, std::shared_ptr, DB::Block const&, unsigned long, std::vector, std::allocator>>*) @ 0x0000000013accc22 8. /build/src/Processors/QueryPlan/JoinStep.cpp:114: DB::JoinStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d01d35 9. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 14. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 15. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 20. ? @ 0x00007f7210eb6ac3 21. ? @ 0x00007f7210f48850 2025.07.13 02:11:13.325780 [ 16756 ] {} TCPHandler: Code: 48. DB::Exception: MergeJoinAlgorithm does not implement ASOF Right join. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::JoinKind&) @ 0x0000000016b4c50b 4. /build/src/Processors/Transforms/MergeJoinTransform.cpp:451: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(DB::JoinKind, DB::JoinStrictness, DB::TableJoin::JoinOnClause const&, std::vector> const&, unsigned long) @ 0x0000000016b44f97 5. /build/src/Processors/Transforms/MergeJoinTransform.cpp:470: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(std::shared_ptr, std::vector> const&, unsigned long) @ 0x0000000016b4532c 6. /build/src/Processors/Merges/IMergingTransform.h:112: DB::MergeJoinTransform::MergeJoinTransform(std::shared_ptr, std::vector> const&, DB::Block const&, unsigned long, unsigned long) @ 0x0000000016b4bab5 7. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::QueryPipelineBuilder::joinPipelinesYShaped(std::unique_ptr>, std::unique_ptr>, std::shared_ptr, DB::Block const&, unsigned long, std::vector, std::allocator>>*) @ 0x0000000013accc22 8. /build/src/Processors/QueryPlan/JoinStep.cpp:114: DB::JoinStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d01d35 9. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 14. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 15. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 20. ? @ 0x00007f7210eb6ac3 21. ? @ 0x00007f7210f48850 2025.07.13 02:11:13.638521 [ 16756 ] {6917be64-78e6-4271-9206-1d56ce582b98} 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]:53230) (comment: 03149_asof_join_ddb_timestamps.sql) (query 16, line 74) (in query: SELECT p.begin, e.value FROM probe0 p ASOF RIGHT JOIN events0 e USING (begin) ORDER BY e.begin ASC;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Planner/PlannerJoins.cpp:1283: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x00000000148e4a3c 5. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0e7d2 6. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 7. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:11:13.661240 [ 16756 ] {} TCPHandler: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Planner/PlannerJoins.cpp:1283: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x00000000148e4a3c 5. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0e7d2 6. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 7. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:11:18.751524 [ 6611 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778c58 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168167bf 10. /build/src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000001680ff45 11. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:11:18.757018 [ 6611 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x0000000016810069 5. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 6. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 2025.07.13 02:11:19.706043 [ 4870 ] {cb3bd105-52d1-46d0-b917-098309284325} 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]:51866) (comment: 02377_majority_insert_quorum_zookeeper_long.sql) (query 31, line 54) (in query: INSERT INTO quorum1 VALUES ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1270: DB::ReplicatedMergeTreeSinkImpl::waitForQuorum(std::shared_ptr const&, String const&, String const&, int, int, unsigned long) const @ 0x000000001652387c 5. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1200: 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'()&&) @ 0x0000000016536d23 6. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x0000000016521f0d 7. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000001651695d 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x0000000016521355 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 10. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f83c 11. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 12. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 13. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 14. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000168e3c3f 15. /build/src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001681130c 16. /build/src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x0000000016806e9c 17. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 22. ? @ 0x00007f7210eb6ac3 23. ? @ 0x00007f7210f48850 2025.07.13 02:11:19.727771 [ 4870 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1270: DB::ReplicatedMergeTreeSinkImpl::waitForQuorum(std::shared_ptr const&, String const&, String const&, int, int, unsigned long) const @ 0x000000001652387c 5. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1200: 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'()&&) @ 0x0000000016536d23 6. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x0000000016521f0d 7. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000001651695d 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x0000000016521355 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 10. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f83c 11. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 12. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 13. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 14. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000168e3c3f 15. /build/src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001681130c 16. /build/src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x0000000016806e9c 17. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 22. ? @ 0x00007f7210eb6ac3 23. ? @ 0x00007f7210f48850 2025.07.13 02:11:27.378485 [ 6637 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778c58 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168167bf 10. /build/src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000001680ff45 11. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:11:27.388666 [ 6637 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x0000000016810069 5. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 6. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 2025.07.13 02:11:28.616465 [ 6612 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000013779f8b 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000137794b8 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778bc3 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678d325 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:11:29.141134 [ 6637 ] {834badf9-a473-4dc0-a342-2e98230f52c4} 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]:33538) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:11:29.176549 [ 6637 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:11:29.337259 [ 3543 ] {d00ff3c3-3e68-42d1-b314-8cd7ed9210ae} 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]:33388) (comment: 02968_sumMap_with_nan.sql) (query 2, line 4) (in query: SELECT sumMap([x],[y]) FROM values('x Float64, y Float64', (4, 1), (1, 2.3), (nan,inf), (6.7,3), (4,4), (5, 1));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 9. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:11:29.361130 [ 3543 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 9. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:11:31.566286 [ 3543 ] {3f4a4194-cfd7-4837-bda5-2c5bdaa24cbe} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 0, should be 1: In scope SELECT base64Encode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33588) (comment: 00732_base64_functions.sql) (query 1, line 4) (in query: SELECT base64Encode();), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000011fa678b 4. /build/src/Functions/IFunction.cpp:539: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000012c80d4d 5. /build/src/Functions/IFunction.cpp:593: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c81533 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:11:31.632190 [ 3543 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 0, should be 1: In scope SELECT base64Encode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000011fa678b 4. /build/src/Functions/IFunction.cpp:539: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000012c80d4d 5. /build/src/Functions/IFunction.cpp:593: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c81533 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:11:31.731050 [ 3543 ] {b1f3dfbd-d2b9-4193-8dd9-0b006934d26c} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 0, should be 1: In scope SELECT base64Decode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33588) (comment: 00732_base64_functions.sql) (query 2, line 5) (in query: SELECT base64Decode();), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000011fa678b 4. /build/src/Functions/IFunction.cpp:539: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000012c80d4d 5. /build/src/Functions/IFunction.cpp:593: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c81533 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:11:31.753123 [ 3543 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 0, should be 1: In scope SELECT base64Decode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000011fa678b 4. /build/src/Functions/IFunction.cpp:539: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000012c80d4d 5. /build/src/Functions/IFunction.cpp:593: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c81533 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:11:31.856427 [ 3543 ] {acf18142-43ec-4977-ba88-34ca8fd0fc1a} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase64Decode doesn't match: passed 0, should be 1: In scope SELECT tryBase64Decode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33588) (comment: 00732_base64_functions.sql) (query 3, line 6) (in query: SELECT tryBase64Decode();), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000011fa678b 4. /build/src/Functions/IFunction.cpp:539: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000012c80d4d 5. /build/src/Functions/IFunction.cpp:593: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c81533 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:11:31.976539 [ 3543 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase64Decode doesn't match: passed 0, should be 1: In scope SELECT tryBase64Decode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000011fa678b 4. /build/src/Functions/IFunction.cpp:539: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000012c80d4d 5. /build/src/Functions/IFunction.cpp:593: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c81533 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:11:32.198062 [ 3543 ] {0c1b271e-54a0-48ff-a4e4-1be8b8fcd1f8} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 2, should be 1: In scope SELECT base64Encode('foo', 'excess argument'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33588) (comment: 00732_base64_functions.sql) (query 4, line 7) (in query: SELECT base64Encode('foo', 'excess argument');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000011fa678b 4. /build/src/Functions/IFunction.cpp:539: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000012c80d4d 5. /build/src/Functions/IFunction.cpp:593: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c81533 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:11:32.224455 [ 3543 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 2, should be 1: In scope SELECT base64Encode('foo', 'excess argument'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000011fa678b 4. /build/src/Functions/IFunction.cpp:539: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000012c80d4d 5. /build/src/Functions/IFunction.cpp:593: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c81533 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:11:32.369180 [ 3543 ] {417fd41d-b6ce-4538-80a3-2ca65522b2a7} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 2, should be 1: In scope SELECT base64Decode('foo', 'excess argument'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33588) (comment: 00732_base64_functions.sql) (query 5, line 8) (in query: SELECT base64Decode('foo', 'excess argument');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000011fa678b 4. /build/src/Functions/IFunction.cpp:539: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000012c80d4d 5. /build/src/Functions/IFunction.cpp:593: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c81533 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:11:32.397603 [ 3543 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 2, should be 1: In scope SELECT base64Decode('foo', 'excess argument'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000011fa678b 4. /build/src/Functions/IFunction.cpp:539: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000012c80d4d 5. /build/src/Functions/IFunction.cpp:593: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c81533 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:11:32.523034 [ 3543 ] {ec310f45-48f6-48fe-84b8-42af37b6d631} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase64Decode doesn't match: passed 2, should be 1: In scope SELECT tryBase64Decode('foo', 'excess argument'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33588) (comment: 00732_base64_functions.sql) (query 6, line 9) (in query: SELECT tryBase64Decode('foo', 'excess argument');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000011fa678b 4. /build/src/Functions/IFunction.cpp:539: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000012c80d4d 5. /build/src/Functions/IFunction.cpp:593: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c81533 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:11:32.536940 [ 3543 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase64Decode doesn't match: passed 2, should be 1: In scope SELECT tryBase64Decode('foo', 'excess argument'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000011fa678b 4. /build/src/Functions/IFunction.cpp:539: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000012c80d4d 5. /build/src/Functions/IFunction.cpp:593: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c81533 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:11:33.433817 [ 27538 ] {e327b722-ff9e-4969-ae6a-e5f829431549} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected '{' before: '1,2,3]\n': (at row 1) : (in file/uri /var/lib/clickhouse/user_files/02267_file_globs_schema_inference_test_9_data1.jsonl): While executing JSONEachRowRowInputFormat: While executing File. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33644) (comment: 02267_file_globs_schema_inference.sh) (query 1, line 1) (in query: select * from file('02267_file_globs_schema_inference_test_9_data*.jsonl') settings schema_inference_use_cache_for_file=0), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/IO/ReadHelpers.cpp:95: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000000fb7e1e9 5. /build/src/IO/ReadHelpers.h:204: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x00000000169f0218 6. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:228: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000169f054b 7. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016940972 8. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 9. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 10. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 11. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 12. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 13. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 14. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 15. /build/src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000015cae3aa 16. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 17. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 18. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 19. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 20. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 21. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 23. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 25. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:11:33.498229 [ 27538 ] {} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected '{' before: '1,2,3]\n': (at row 1) : (in file/uri /var/lib/clickhouse/user_files/02267_file_globs_schema_inference_test_9_data1.jsonl): While executing JSONEachRowRowInputFormat: While executing File. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/IO/ReadHelpers.cpp:95: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000000fb7e1e9 5. /build/src/IO/ReadHelpers.h:204: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x00000000169f0218 6. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:228: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000169f054b 7. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016940972 8. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 9. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 10. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 11. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 12. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 13. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 14. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 15. /build/src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000015cae3aa 16. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 17. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 18. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 19. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 20. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 21. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 23. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 25. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:11:33.650464 [ 4871 ] {4ffc145e-2f52-46e5-af91-ed62ac8c999c} executeQuery: Code: 57. DB::Exception: Table test_mnd0md7f.t_map_lc already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37308) (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 = 384, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 278287885, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 3029003, merge_max_block_size = 9957, 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 = 1, index_granularity_bytes = 20478776, 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 = false, cache_populated_by_fetch = false, marks_compress_block_size = 76105, primary_key_compress_block_size = 70058, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:11:33.728374 [ 4871 ] {} TCPHandler: Code: 57. DB::Exception: Table test_mnd0md7f.t_map_lc already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:11:33.940679 [ 16758 ] {44899299-85a3-48d3-843f-4e28655ccc07} 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]:43384) (comment: 03156_tuple_map_low_cardinality.sql) (in query: DROP DATABASE IF EXISTS test_mnd0md7f SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:11:33.947892 [ 16758 ] {44899299-85a3-48d3-843f-4e28655ccc07} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:11:34.132097 [ 3543 ] {e47f61f5-871a-4fe4-8614-3d2e7eb7c872} executeQuery: Code: 117. DB::Exception: Failed to base64Decode input 'Zm9vYmF=Zm9v': In scope SELECT base64Decode('Zm9vYmF=Zm9v'). (INCORRECT_DATA) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33588) (comment: 00732_base64_functions.sql) (query 12, line 20) (in query: -- test with invalid inputs SELECT base64Decode('Zm9vYmF=Zm9v');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, String&&) @ 0x000000000a9f1eeb 4. /build/src/Functions/FunctionBase64Conversion.h:146: DB::Base64Decode<(DB::Base64Variant)0>::perform(std::basic_string_view>, char8_t*) @ 0x000000000a9f1e4e 5. /build/src/Functions/FunctionBase64Conversion.h:252: DB::FunctionBase64Conversion>::execute(DB::ColumnString const&, unsigned long) @ 0x000000000a9f1c66 6. /build/src/Functions/FunctionBase64Conversion.h:221: DB::FunctionBase64Conversion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a9f1569 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 28. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 29. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 2025.07.13 02:11:34.142428 [ 3543 ] {} TCPHandler: Code: 117. DB::Exception: Failed to base64Decode input 'Zm9vYmF=Zm9v': In scope SELECT base64Decode('Zm9vYmF=Zm9v'). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, String&&) @ 0x000000000a9f1eeb 4. /build/src/Functions/FunctionBase64Conversion.h:146: DB::Base64Decode<(DB::Base64Variant)0>::perform(std::basic_string_view>, char8_t*) @ 0x000000000a9f1e4e 5. /build/src/Functions/FunctionBase64Conversion.h:252: DB::FunctionBase64Conversion>::execute(DB::ColumnString const&, unsigned long) @ 0x000000000a9f1c66 6. /build/src/Functions/FunctionBase64Conversion.h:221: DB::FunctionBase64Conversion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a9f1569 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 28. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 29. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 2025.07.13 02:11:34.462029 [ 3543 ] {9e769fd6-6a55-4002-ac00-6f47953f4495} executeQuery: Code: 117. DB::Exception: Failed to base64Decode input 'foo': In scope SELECT base64Decode('foo'). (INCORRECT_DATA) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33588) (comment: 00732_base64_functions.sql) (query 14, line 25) (in query: SELECT base64Decode('foo');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, String&&) @ 0x000000000a9f1eeb 4. /build/src/Functions/FunctionBase64Conversion.h:146: DB::Base64Decode<(DB::Base64Variant)0>::perform(std::basic_string_view>, char8_t*) @ 0x000000000a9f1e4e 5. /build/src/Functions/FunctionBase64Conversion.h:252: DB::FunctionBase64Conversion>::execute(DB::ColumnString const&, unsigned long) @ 0x000000000a9f1c66 6. /build/src/Functions/FunctionBase64Conversion.h:221: DB::FunctionBase64Conversion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a9f1569 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 28. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 29. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 2025.07.13 02:11:34.473251 [ 3543 ] {} TCPHandler: Code: 117. DB::Exception: Failed to base64Decode input 'foo': In scope SELECT base64Decode('foo'). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, String&&) @ 0x000000000a9f1eeb 4. /build/src/Functions/FunctionBase64Conversion.h:146: DB::Base64Decode<(DB::Base64Variant)0>::perform(std::basic_string_view>, char8_t*) @ 0x000000000a9f1e4e 5. /build/src/Functions/FunctionBase64Conversion.h:252: DB::FunctionBase64Conversion>::execute(DB::ColumnString const&, unsigned long) @ 0x000000000a9f1c66 6. /build/src/Functions/FunctionBase64Conversion.h:221: DB::FunctionBase64Conversion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a9f1569 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 28. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 29. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 2025.07.13 02:11:34.885849 [ 3543 ] {e98363df-68e9-4c24-8cdb-986934214cc7} executeQuery: Code: 117. DB::Exception: Failed to base64Decode input 'aoeo054640eu=': In scope SELECT base64Decode('aoeo054640eu='). (INCORRECT_DATA) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33588) (comment: 00732_base64_functions.sql) (query 16, line 28) (in query: SELECT base64Decode('aoeo054640eu=');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, String&&) @ 0x000000000a9f1eeb 4. /build/src/Functions/FunctionBase64Conversion.h:146: DB::Base64Decode<(DB::Base64Variant)0>::perform(std::basic_string_view>, char8_t*) @ 0x000000000a9f1e4e 5. /build/src/Functions/FunctionBase64Conversion.h:252: DB::FunctionBase64Conversion>::execute(DB::ColumnString const&, unsigned long) @ 0x000000000a9f1c66 6. /build/src/Functions/FunctionBase64Conversion.h:221: DB::FunctionBase64Conversion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a9f1569 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 28. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 29. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 2025.07.13 02:11:34.913210 [ 3543 ] {} TCPHandler: Code: 117. DB::Exception: Failed to base64Decode input 'aoeo054640eu=': In scope SELECT base64Decode('aoeo054640eu='). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, String&&) @ 0x000000000a9f1eeb 4. /build/src/Functions/FunctionBase64Conversion.h:146: DB::Base64Decode<(DB::Base64Variant)0>::perform(std::basic_string_view>, char8_t*) @ 0x000000000a9f1e4e 5. /build/src/Functions/FunctionBase64Conversion.h:252: DB::FunctionBase64Conversion>::execute(DB::ColumnString const&, unsigned long) @ 0x000000000a9f1c66 6. /build/src/Functions/FunctionBase64Conversion.h:221: DB::FunctionBase64Conversion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a9f1569 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 28. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 29. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 2025.07.13 02:11:34.958175 [ 5117 ] {7f2a3743-158c-498b-9dd9-4809ef577210} 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]:33296) (comment: 01947_mv_subquery.sql) (query 11, line 53) (in query: SELECT '1947 #2 CHECK - TRUE' as test, ProfileEvents['SleepFunctionCalls'] as sleep_calls, ProfileEvents['SleepFunctionMicroseconds'] as sleep_microseconds FROM system.query_log WHERE query like '%INSERT into src SELECT number + 100 as id, 1 FROM numbers(2)%' AND type > 1 AND current_database = currentDatabase() AND event_date >= yesterday() FORMAT JSONEachRow;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 9. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:11:35.022993 [ 5117 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 9. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:11:38.064882 [ 6612 ] {05496338-cab3-4284-9535-8c515551cf73} 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]:33702) (comment: 01412_row_from_totals.sql) (query 9, line 13) (in query: SELECT EventDate FROM ( SELECT EventDate FROM tracking_events_tmp AS t1 WHERE (EventDate >= toDate('2020-07-10')) AND (EventDate <= toDate('2020-07-11')) AND (APIKey = 2) GROUP BY EventDate ) FULL OUTER JOIN ( SELECT EventDate FROM remote('127.0.0.{1,3}', currentDatabase(), open_events_tmp) AS t2 WHERE (EventDate >= toDate('2020-07-10')) AND (EventDate <= toDate('2020-07-11')) AND (APIKey = 2) GROUP BY EventDate WITH TOTALS ) USING EventDate ORDER BY EventDate settings totals_mode = 'after_having_auto', group_by_overflow_mode = 'any', max_rows_to_group_by = 10000000, joined_subquery_requires_alias=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/executeQuery.cpp:1338: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba8300 5. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 6. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 7. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 12. ? @ 0x00007f7210eb6ac3 13. ? @ 0x00007f7210f48850 2025.07.13 02:11:38.121823 [ 27538 ] {77b329a1-c13a-462e-9130-18a63fdb7edd} executeQuery: Code: 38. DB::Exception: Cannot parse date: value is too short: while converting '202001-06' to Date. (CANNOT_PARSE_DATE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33656) (comment: 01073_bad_alter_partition.sql) (query 11, line 19) (in query: ALTER TABLE merge_tree DROP PARTITION '202001-06';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/IO/ReadHelpers.cpp:1389: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x000000000fb8dedb 5. /build/src/IO/ReadHelpers.cpp:0: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000000fb8de02 6. /build/src/IO/ReadHelpers.h:850: DB::SerializationDate::deserializeTextEscaped(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013bb0faa 7. /build/src/DataTypes/Serializations/SerializationDate.cpp:20: DB::SerializationDate::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013bb0efe 8. /build/src/Interpreters/convertFieldToType.cpp:578: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014b775e9 9. /build/src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014b75587 10. /build/src/Interpreters/convertFieldToType.cpp:643: DB::convertFieldToTypeOrThrow(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014b78498 11. /build/src/Storages/MergeTree/MergeTreeData.cpp:6388: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x000000001625ef37 12. /build/src/Storages/MergeTree/MergeTreeData.cpp:5405: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x0000000016276770 13. /build/src/Interpreters/InterpreterAlterQuery.cpp:241: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd450 14. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:11:38.124301 [ 6612 ] {} TCPHandler: Code: 731. DB::Exception: use_query_cache and overflow_mode != 'throw' cannot be used together. (QUERY_CACHE_USED_WITH_NON_THROW_OVERFLOW_MODE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/executeQuery.cpp:1338: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba8300 5. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 6. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 7. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 12. ? @ 0x00007f7210eb6ac3 13. ? @ 0x00007f7210f48850 2025.07.13 02:11:38.127855 [ 27538 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date: value is too short: while converting '202001-06' to Date. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/IO/ReadHelpers.cpp:1389: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x000000000fb8dedb 5. /build/src/IO/ReadHelpers.cpp:0: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000000fb8de02 6. /build/src/IO/ReadHelpers.h:850: DB::SerializationDate::deserializeTextEscaped(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013bb0faa 7. /build/src/DataTypes/Serializations/SerializationDate.cpp:20: DB::SerializationDate::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013bb0efe 8. /build/src/Interpreters/convertFieldToType.cpp:578: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014b775e9 9. /build/src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014b75587 10. /build/src/Interpreters/convertFieldToType.cpp:643: DB::convertFieldToTypeOrThrow(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014b78498 11. /build/src/Storages/MergeTree/MergeTreeData.cpp:6388: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x000000001625ef37 12. /build/src/Storages/MergeTree/MergeTreeData.cpp:5405: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x0000000016276770 13. /build/src/Interpreters/InterpreterAlterQuery.cpp:241: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd450 14. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:11:38.923428 [ 6168 ] {9322004e-ed2c-4ce7-92e0-32d2dbc4b689} executeQuery: Code: 223. DB::Exception: 'max_types' argument for Dynamic type should be a positive integer between 0 and 254. (UNEXPECTED_AST_STRUCTURE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33626) (comment: 03151_dynamic_type_scale_max_types.sql) (query 16, line 27) (in query: ALTER TABLE to_table MODIFY COLUMN n2 Dynamic(max_types=500);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000a8668eb 4. /build/src/DataTypes/DataTypeDynamic.cpp:82: DB::create(std::shared_ptr const&) @ 0x0000000013b045e7 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013b0e25b 6. /build/src/DataTypes/DataTypeFactory.cpp:91: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000013b0dcfe 7. /build/src/Storages/AlterCommands.cpp:174: DB::AlterCommand::parse(DB::ASTAlterCommand const*) @ 0x0000000015c095ae 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:158: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fc459 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:11:38.941065 [ 6168 ] {} TCPHandler: Code: 223. DB::Exception: 'max_types' argument for Dynamic type should be a positive integer between 0 and 254. (UNEXPECTED_AST_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000a8668eb 4. /build/src/DataTypes/DataTypeDynamic.cpp:82: DB::create(std::shared_ptr const&) @ 0x0000000013b045e7 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013b0e25b 6. /build/src/DataTypes/DataTypeFactory.cpp:91: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000013b0dcfe 7. /build/src/Storages/AlterCommands.cpp:174: DB::AlterCommand::parse(DB::ASTAlterCommand const*) @ 0x0000000015c095ae 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:158: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fc459 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:11:39.709358 [ 3542 ] {94cad05a-19a9-491f-a255-58c1108fb409} 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]:33762) (comment: 03364_gorilla_codec_parameters.sql) (query 4, line 4) (in query: DETACH TABLE 03364_gorilla;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Databases/DatabaseReplicated.cpp:1106: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013cc3688 5. /build/src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc384b 6. /build/src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833287 7. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 8. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 9. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:11:39.763877 [ 3542 ] {} TCPHandler: Code: 80. DB::Exception: DETACH TABLE is not allowed for Replicated databases. Use DETACH TABLE PERMANENTLY or SYSTEM RESTART REPLICA or set database_replicated_always_detach_permanently to 1. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Databases/DatabaseReplicated.cpp:1106: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013cc3688 5. /build/src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc384b 6. /build/src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833287 7. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 8. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 9. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:11:39.978995 [ 5117 ] {ba0796e3-e7fb-4086-a512-765999f20442} executeQuery: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38362) (query 1, line 1) (in query: select _path,_file from file('nonexist.txt', 'CSV', 'val1 char')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Storages/StorageFile.cpp:1630: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000015caf8eb 5. /build/src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000148b600e 6. /build/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&) @ 0x00000000148ad029 7. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 8. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 10. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:11:40.002363 [ 5117 ] {} TCPHandler: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Storages/StorageFile.cpp:1630: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000015caf8eb 5. /build/src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000148b600e 6. /build/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&) @ 0x00000000148ad029 7. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 8. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 10. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:11:47.419005 [ 5117 ] {8acc8121-b070-4645-be2c-7f6127b1a2fd} 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]:38448) (comment: 03335_empty_blobs_on_azure.sh) (query 2, line 4) (in query: CREATE TABLE test_empty_blobs (`key` Int, `arr` Array(UInt32)) ENGINE = MergeTree ORDER BY tuple() SETTINGS min_bytes_for_wide_part = 1, min_rows_for_wide_part = 1, max_file_name_length = 127, min_bytes_for_full_part_storage = 1, disk = disk(type = object_storage, metadata_type = local, object_storage_type = azure_blob_storage, name = 'cont-03335-empty-blobs-on-azure-test-pob9zuat', path = '/var/lib/clickhouse/disks/cont-03335-empty-blobs-on-azure-test-pob9zuat/tables', container_name = 'cont-03335-empty-blobs-on-azure-test-pob9zuat', endpoint = 'http://localhost:10000/devstoreaccount1/cont-03335-empty-blobs-on-azure-test-pob9zuat/plain-tables', account_name = 'devstoreaccount1', account_key = 'Eby8vdM02xNOcqFlqUwJPLlmEtlCDXJ1OUzFT50uSRZ6IFsuFq2UVErCz4I6tq/K1SZFPTOtr/KBHBeksoGMGw=='), index_granularity = 32722, ratio_of_defaults_for_sparse_serialization = 0.26805347204208374, replace_long_file_name_to_hash = false, compact_parts_max_bytes_to_buffer = 233232225, compact_parts_max_granules_to_buffer = 6, compact_parts_merge_max_bytes_to_prefetch_part = 15583824, merge_max_block_size = 2111, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 6012482839, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 5700272251, index_granularity_bytes = 2611020, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 50, 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 = 84813, primary_key_compress_block_size = 21909, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: std::runtime_error::runtime_error(String const&) @ 0x000000001f56ddf4 1. /build/contrib/azure/sdk/core/azure-core/src/exception.cpp:20: Azure::Core::RequestFailedException::RequestFailedException(String const&) @ 0x000000001b199849 2. /build/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&) @ 0x000000001b195c26 3. /build/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) @ 0x000000001b18f0b3 4. /build/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&) @ 0x000000001b18e1b4 5. /build/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 @ 0x000000001b1ca78c 6. /build/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 @ 0x000000001b1a8e0a 7. /build/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 @ 0x000000001b1c82ac 8. /build/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 @ 0x000000001b1d41b9 9. /build/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 @ 0x000000001b21cb84 10. /build/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 @ 0x000000001b21d0b0 11. /build/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 @ 0x000000001b1c6e81 12. /build/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 @ 0x000000001b1cab8b 13. /build/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 @ 0x000000001b1bc1e6 14. /build/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 @ 0x000000001b1d49ad 15. /build/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&) @ 0x000000001b1eca23 16. /build/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 @ 0x000000001b1dc0b5 17. /build/src/Disks/ObjectStorages/AzureBlobStorage/AzureBlobStorageCommon.cpp:105: DB::AzureBlobStorage::ContainerClientWrapper::GetProperties() const @ 0x00000000133d3c1f 18. /build/src/Disks/ObjectStorages/AzureBlobStorage/AzureBlobStorageCommon.cpp:319: DB::AzureBlobStorage::getContainerClient(DB::AzureBlobStorage::ConnectionParams const&, bool) @ 0x00000000133d69f0 19. /build/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:se190107] (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) @ 0x0000000013e4638a 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013e438c1 21. /build/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:se190107] (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) @ 0x0000000013e43074 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013dce296 23. /build/src/Disks/DiskFromAST.cpp:57: std::shared_ptr std::__function::__policy_invoker (std::map, std::less, std::allocator>>> const&)>::__call_impl[abi:se190107], 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&) @ 0x0000000016431a50 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000143667ec 25. /build/src/Disks/DiskFromAST.cpp:56: DB::getOrCreateCustomDisk(Poco::AutoPtr, String const&, std::shared_ptr, bool) @ 0x0000000016430dd7 26. /build/src/Disks/DiskFromAST.cpp:117: DB::DiskConfigurationFlattener::visit(std::shared_ptr&, DB::DiskConfigurationFlattener::Data&) @ 0x0000000016431f3c 27. /build/src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x0000000016431db5 28. /build/src/Interpreters/InDepthNodeVisitor.h:61: DB::DiskFromAST::createCustomDisk(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000164316ca 29. /build/src/Storages/MergeTree/MergeTreeSettings.cpp:398: DB::MergeTreeSettingsImpl::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x0000000016403b69 30. /build/src/Storages/MergeTree/MergeTreeSettings.cpp:714: DB::MergeTreeSettings::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x0000000016406404 31. /build/src/Storages/MergeTree/registerStorageMergeTree.cpp:705: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000165521de 2025.07.13 02:11:47.434071 [ 4870 ] {44475545-c2d0-4895-830e-7553573cf1d1} executeQuery: Code: 469. DB::Exception: Constraint `_implicit_sign_column_constraint` for table test_15.collapsing_merge_tree (f893509a-9d1f-4e72-b204-f991ad42f8ed) is violated at row 1. Expression: (Sign IN [-1, 1]). Column values: Sign = 5. (VIOLATED_CONSTRAINT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38544) (comment: 02918_implicit_sign_column_constraints_for_collapsing_engine.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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&) @ 0x0000000013bf7039 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000016b2113c 5. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 7. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 10. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 11. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000168e3c3f 12. /build/src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001681130c 13. /build/src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x0000000016806e9c 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:11:47.455644 [ 5117 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: std::runtime_error::runtime_error(String const&) @ 0x000000001f56ddf4 1. /build/contrib/azure/sdk/core/azure-core/src/exception.cpp:20: Azure::Core::RequestFailedException::RequestFailedException(String const&) @ 0x000000001b199849 2. /build/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&) @ 0x000000001b195c26 3. /build/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) @ 0x000000001b18f0b3 4. /build/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&) @ 0x000000001b18e1b4 5. /build/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 @ 0x000000001b1ca78c 6. /build/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 @ 0x000000001b1a8e0a 7. /build/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 @ 0x000000001b1c82ac 8. /build/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 @ 0x000000001b1d41b9 9. /build/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 @ 0x000000001b21cb84 10. /build/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 @ 0x000000001b21d0b0 11. /build/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 @ 0x000000001b1c6e81 12. /build/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 @ 0x000000001b1cab8b 13. /build/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 @ 0x000000001b1bc1e6 14. /build/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 @ 0x000000001b1d49ad 15. /build/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&) @ 0x000000001b1eca23 16. /build/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 @ 0x000000001b1dc0b5 17. /build/src/Disks/ObjectStorages/AzureBlobStorage/AzureBlobStorageCommon.cpp:105: DB::AzureBlobStorage::ContainerClientWrapper::GetProperties() const @ 0x00000000133d3c1f 18. /build/src/Disks/ObjectStorages/AzureBlobStorage/AzureBlobStorageCommon.cpp:319: DB::AzureBlobStorage::getContainerClient(DB::AzureBlobStorage::ConnectionParams const&, bool) @ 0x00000000133d69f0 19. /build/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:se190107] (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) @ 0x0000000013e4638a 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013e438c1 21. /build/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:se190107] (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) @ 0x0000000013e43074 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013dce296 23. /build/src/Disks/DiskFromAST.cpp:57: std::shared_ptr std::__function::__policy_invoker (std::map, std::less, std::allocator>>> const&)>::__call_impl[abi:se190107], 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&) @ 0x0000000016431a50 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000143667ec 25. /build/src/Disks/DiskFromAST.cpp:56: DB::getOrCreateCustomDisk(Poco::AutoPtr, String const&, std::shared_ptr, bool) @ 0x0000000016430dd7 26. /build/src/Disks/DiskFromAST.cpp:117: DB::DiskConfigurationFlattener::visit(std::shared_ptr&, DB::DiskConfigurationFlattener::Data&) @ 0x0000000016431f3c 27. /build/src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x0000000016431db5 28. /build/src/Interpreters/InDepthNodeVisitor.h:61: DB::DiskFromAST::createCustomDisk(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000164316ca 29. /build/src/Storages/MergeTree/MergeTreeSettings.cpp:398: DB::MergeTreeSettingsImpl::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x0000000016403b69 30. /build/src/Storages/MergeTree/MergeTreeSettings.cpp:714: DB::MergeTreeSettings::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x0000000016406404 31. /build/src/Storages/MergeTree/registerStorageMergeTree.cpp:705: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000165521de 2025.07.13 02:11:47.481934 [ 4870 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `_implicit_sign_column_constraint` for table test_15.collapsing_merge_tree (f893509a-9d1f-4e72-b204-f991ad42f8ed) is violated at row 1. Expression: (Sign IN [-1, 1]). Column values: Sign = 5. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&) @ 0x0000000013bf7039 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000016b2113c 5. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 7. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 10. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 11. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000168e3c3f 12. /build/src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001681130c 13. /build/src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x0000000016806e9c 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:11:54.279004 [ 6611 ] {948f52ae-f941-4dfe-93ed-37866d82942c} 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]:39304) (comment: 03001_bad_error_message_higher_order_functions.sh) (query 1, line 1) (in query: SELECT arrayMap((x,y) -> x + y, [1,2,3], [1,2])), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, unsigned long const&, unsigned long const&) @ 0x000000000e96680b 4. /build/src/Functions/array/FunctionArrayMapped.h:335: DB::FunctionArrayMapped::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e96b127 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Interpreters/ActionsDAG.cpp:413: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x0000000013eba819 13. /build/src/Interpreters/ActionsDAG.cpp:346: DB::ActionsDAG::addFunction(DB::FunctionNode const&, std::vector>, String) @ 0x0000000013ebaf68 14. /build/src/Planner/PlannerActionsVisitor.cpp:536: DB::(anonymous namespace)::PlannerActionsVisitorImpl::visitImpl(std::shared_ptr) @ 0x0000000013efb3e7 15. /build/src/Planner/PlannerActionsVisitor.cpp:645: DB::PlannerActionsVisitor::visit(DB::ActionsDAG&, std::shared_ptr) @ 0x0000000013ef48c9 16. /build/src/Planner/Utils.cpp:252: DB::buildActionsDAGFromExpressionNode(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&) @ 0x0000000013f058ed 17. /build/src/Planner/PlannerExpressionAnalysis.cpp:377: DB::buildExpressionAnalysisResult(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::PlannerQueryProcessingInfo const&) @ 0x00000000148ebc0c 18. /build/src/Planner/Planner.cpp:1593: DB::Planner::buildPlanForQueryNode() @ 0x0000000014899673 19. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 21. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:11:54.375305 [ 6611 ] {} TCPHandler: Code: 190. DB::Exception: Arrays passed to arrayMap must have equal size. Argument 3 has size 2 which differs with the size of another argument, 3. (SIZES_OF_ARRAYS_DONT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, unsigned long const&, unsigned long const&) @ 0x000000000e96680b 4. /build/src/Functions/array/FunctionArrayMapped.h:335: DB::FunctionArrayMapped::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e96b127 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Interpreters/ActionsDAG.cpp:413: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x0000000013eba819 13. /build/src/Interpreters/ActionsDAG.cpp:346: DB::ActionsDAG::addFunction(DB::FunctionNode const&, std::vector>, String) @ 0x0000000013ebaf68 14. /build/src/Planner/PlannerActionsVisitor.cpp:536: DB::(anonymous namespace)::PlannerActionsVisitorImpl::visitImpl(std::shared_ptr) @ 0x0000000013efb3e7 15. /build/src/Planner/PlannerActionsVisitor.cpp:645: DB::PlannerActionsVisitor::visit(DB::ActionsDAG&, std::shared_ptr) @ 0x0000000013ef48c9 16. /build/src/Planner/Utils.cpp:252: DB::buildActionsDAGFromExpressionNode(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&) @ 0x0000000013f058ed 17. /build/src/Planner/PlannerExpressionAnalysis.cpp:377: DB::buildExpressionAnalysisResult(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::PlannerQueryProcessingInfo const&) @ 0x00000000148ebc0c 18. /build/src/Planner/Planner.cpp:1593: DB::Planner::buildPlanForQueryNode() @ 0x0000000014899673 19. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 21. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:11:57.714839 [ 6166 ] {7d05207e-bc35-48aa-91e4-5a2fe81bef93} executeQuery: Code: 469. DB::Exception: Constraint `_implicit_sign_column_constraint` for table test_15.versioned_collapsing_merge_tree (2a1b76da-c80d-474c-a120-cf981eb52596) is violated at row 1. Expression: (Sign IN [-1, 1]). Column values: Sign = 5. (VIOLATED_CONSTRAINT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39444) (comment: 02918_implicit_sign_column_constraints_for_collapsing_engine.sh) (query 1, line 1) (in query: INSERT INTO versioned_collapsing_merge_tree VALUES ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&) @ 0x0000000013bf7039 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000016b2113c 5. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 7. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 10. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 11. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000168e3c3f 12. /build/src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001681130c 13. /build/src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x0000000016806e9c 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:11:57.738742 [ 6166 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `_implicit_sign_column_constraint` for table test_15.versioned_collapsing_merge_tree (2a1b76da-c80d-474c-a120-cf981eb52596) is violated at row 1. Expression: (Sign IN [-1, 1]). Column values: Sign = 5. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&) @ 0x0000000013bf7039 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000016b2113c 5. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 7. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 10. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 11. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000168e3c3f 12. /build/src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001681130c 13. /build/src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x0000000016806e9c 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:11:58.084982 [ 11479 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:11:58.880306 [ 16758 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000013779f8b 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000137794b8 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778bc3 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678d325 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:11:59.578760 [ 5018 ] {3a59683d-e11b-4bde-a514-5f1e09f83a94} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:49456). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fc62e75 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fc64467 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x0000000009fb95be 5. /build/src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000001681a8e6 6. /build/src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811c0c 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:11:59.663623 [ 5018 ] {3a59683d-e11b-4bde-a514-5f1e09f83a94} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:49456). (NETWORK_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:49456) (comment: 03012_prewhere_merge_distributed.sql) (query 10, line 17) (in query: SELECT `__table1`.`name` AS `name` FROM `test_kc3k71ue`.`test_local` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fc62e75 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fc64467 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x0000000009fb95be 5. /build/src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000001681a8e6 6. /build/src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811c0c 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:11:59.684166 [ 5018 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:49456). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fc62e75 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fc64467 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x0000000009fb95be 5. /build/src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000001681a8e6 6. /build/src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811c0c 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:11:59.801177 [ 16763 ] {88f2b4e4-43a8-4d9d-9bb9-a7fa42e9ec30} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=0): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread): Child table: test_kc3k71ue.test_distributed (0d297eab-cfc9-4172-8fd9-a16cf317c0b0). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38608) (comment: 03012_prewhere_merge_distributed.sql) (query 10, line 17) (in query: SELECT count() FROM merge(currentDatabase(), '^test_distributed$') PREWHERE name GLOBAL IN ( SELECT name FROM test_distributed );), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x00000000163993d1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016396620 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001639641f 10. /build/src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000163b2bd7 11. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x00000000162ea22d 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x00000000162e6974 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x00000000163d9d66 14. /build/src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:279: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x0000000016d78a31 15. /build/src/Storages/MergeTree/MergeTreeReadPool.cpp:159: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x0000000016d96c0a 16. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5520 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 18. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 22. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:11:59.968047 [ 16763 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=0): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread): Child table: test_kc3k71ue.test_distributed (0d297eab-cfc9-4172-8fd9-a16cf317c0b0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x00000000163993d1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016396620 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001639641f 10. /build/src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000163b2bd7 11. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x00000000162ea22d 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x00000000162e6974 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x00000000163d9d66 14. /build/src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:279: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x0000000016d78a31 15. /build/src/Storages/MergeTree/MergeTreeReadPool.cpp:159: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x0000000016d96c0a 16. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5520 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 18. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 22. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000168cfa64 8. /build/src/Storages/buildQueryTreeForShard.cpp:315: DB::(anonymous namespace)::executeSubqueryNode(std::shared_ptr const&, std::shared_ptr&, unsigned long) @ 0x0000000015f721aa 9. /build/src/Storages/buildQueryTreeForShard.cpp:417: DB::buildQueryTreeForShard(std::shared_ptr const&, std::shared_ptr) @ 0x0000000015f6f029 10. /build/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) @ 0x0000000015c833dd 11. /build/src/Storages/StorageMerge.cpp:1199: DB::ReadFromMerge::createPlanForTable(std::shared_ptr const&, DB::SelectQueryInfo&, DB::QueryProcessingStage::Enum, unsigned long, std::tuple, std::shared_ptr, String> const&, std::vector> const&, std::optional const&, std::shared_ptr, unsigned long) const @ 0x0000000015d63a3a 12. /build/src/Storages/StorageMerge.cpp:752: DB::ReadFromMerge::createChildrenPlans(DB::SelectQueryInfo&) const @ 0x0000000015d5e787 13. /build/src/Storages/StorageMerge.cpp:596: DB::ReadFromMerge::filterTablesAndCreateChildrenPlans() @ 0x0000000015d5a7b7 14. /build/src/Storages/StorageMerge.cpp:1624: DB::ReadFromMerge::applyFilters(DB::ActionDAGNodes) @ 0x0000000015d692e3 15. /build/src/Processors/QueryPlan/SourceStepWithFilter.h:39: DB::SourceStepWithFilterBase::applyFilters() @ 0x0000000016dd353d 16. /build/src/Processors/QueryPlan/Optimizations/optimizePrimaryKeyConditionAndLimit.cpp:55: DB::QueryPlanOptimizations::optimizePrimaryKeyConditionAndLimit(std::vector> const&) @ 0x0000000016dd32ed 17. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:125: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1941 18. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 21. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:12:00.528546 [ 5998 ] {a504f02d-9ee0-4a87-b30e-7a05f97ddae7} executeQuery: Code: 48. DB::Exception: Alter of type 'MODIFY_ORDER_BY' is not supported by storage Distributed. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52840) (comment: 00910_crash_when_distributed_modify_order_by.sql) (query 6, line 8) (in query: ALTER TABLE union2 MODIFY ORDER BY a;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::AlterCommand::Type const&, String&&) @ 0x0000000013380c0b 4. /build/src/Storages/StorageDistributed.cpp:1260: DB::StorageDistributed::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000015c88b7b 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd033 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:12:00.535806 [ 5998 ] {} TCPHandler: Code: 48. DB::Exception: Alter of type 'MODIFY_ORDER_BY' is not supported by storage Distributed. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::AlterCommand::Type const&, String&&) @ 0x0000000013380c0b 4. /build/src/Storages/StorageDistributed.cpp:1260: DB::StorageDistributed::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000015c88b7b 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd033 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:12:02.983891 [ 10911 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:12:06.601715 [ 16756 ] {9d72ead8-1496-43cf-8dc7-95ccd322328a} executeQuery: Code: 469. DB::Exception: Constraint `_implicit_sign_column_constraint` for table test_15.collapsing_merge_tree_2 (5dc182e7-60b7-4c7b-be6d-4fa279483dd5) is violated at row 1. Expression: (Sign IN [-1, 1]). Column values: Sign = 5. (VIOLATED_CONSTRAINT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53054) (comment: 02918_implicit_sign_column_constraints_for_collapsing_engine.sh) (query 1, line 1) (in query: INSERT INTO collapsing_merge_tree_2 VALUES ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&) @ 0x0000000013bf7039 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000016b2113c 5. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 7. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 10. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 11. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000168e3c3f 12. /build/src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001681130c 13. /build/src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x0000000016806e9c 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:12:06.617203 [ 16756 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `_implicit_sign_column_constraint` for table test_15.collapsing_merge_tree_2 (5dc182e7-60b7-4c7b-be6d-4fa279483dd5) is violated at row 1. Expression: (Sign IN [-1, 1]). Column values: Sign = 5. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&) @ 0x0000000013bf7039 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000016b2113c 5. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 7. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 10. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 11. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000168e3c3f 12. /build/src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001681130c 13. /build/src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x0000000016806e9c 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:12:07.373061 [ 5117 ] {f477185c-5ae7-468f-bc4f-9e159dc40ae8} executeQuery: Code: 53. DB::Exception: Type mismatch of columns to JOIN by: __table1.k :: UInt64 at left, __table3.key :: UInt32 at right. (TYPE_MISMATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39474) (comment: 02242_join_rocksdb.sql) (query 27, line 47) (in query: -- can't promote right table type SELECT * FROM (SELECT toUInt64(k) as k FROM t2) as t2 INNER JOIN rdb ON rdb.key == t2.k;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String const&, String&&) @ 0x0000000013f68c6b 4. /build/src/Interpreters/JoinUtils.cpp:402: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, DB::Block const&, std::vector> const&) @ 0x0000000014916259 5. /build/src/Interpreters/DirectJoin.cpp:115: DB::DirectKeyValueJoin::checkTypesOfKeys(DB::Block const&) const @ 0x00000000144abf42 6. /build/src/Processors/Transforms/JoiningTransform.cpp:27: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000016b35858 7. /build/src/Processors/QueryPlan/JoinStep.cpp:240: DB::FilledJoinStep::FilledJoinStep(DB::Block const&, std::shared_ptr, unsigned long) @ 0x0000000016d04238 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016ddaa77 9. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 10. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:12:07.388135 [ 5117 ] {} TCPHandler: Code: 53. DB::Exception: Type mismatch of columns to JOIN by: __table1.k :: UInt64 at left, __table3.key :: UInt32 at right. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String const&, String&&) @ 0x0000000013f68c6b 4. /build/src/Interpreters/JoinUtils.cpp:402: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, DB::Block const&, std::vector> const&) @ 0x0000000014916259 5. /build/src/Interpreters/DirectJoin.cpp:115: DB::DirectKeyValueJoin::checkTypesOfKeys(DB::Block const&) const @ 0x00000000144abf42 6. /build/src/Processors/Transforms/JoiningTransform.cpp:27: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000016b35858 7. /build/src/Processors/QueryPlan/JoinStep.cpp:240: DB::FilledJoinStep::FilledJoinStep(DB::Block const&, std::shared_ptr, unsigned long) @ 0x0000000016d04238 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016ddaa77 9. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 10. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:12:08.362583 [ 5117 ] {c359bfaf-cd93-4ae0-b0ec-32bbc4625e63} 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]:39474) (comment: 02242_join_rocksdb.sql) (query 31, line 56) (in query: SELECT * FROM t1 RIGHT JOIN rdb ON rdb.key == t1.k;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Planner/PlannerJoins.cpp:1283: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x00000000148e4a3c 5. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0e7d2 6. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 7. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:12:08.375731 [ 5117 ] {} TCPHandler: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Planner/PlannerJoins.cpp:1283: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x00000000148e4a3c 5. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0e7d2 6. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 7. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:12:08.974344 [ 5117 ] {09b51f32-6f6a-4d4f-9321-7dc0f78db87a} 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]:39474) (comment: 02242_join_rocksdb.sql) (query 33, line 59) (in query: SELECT * FROM t1 FULL JOIN rdb ON rdb.key == t1.k;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Planner/PlannerJoins.cpp:1283: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x00000000148e4a3c 5. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0e7d2 6. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 7. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:12:08.995889 [ 5117 ] {} TCPHandler: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Planner/PlannerJoins.cpp:1283: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x00000000148e4a3c 5. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0e7d2 6. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 7. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:12:09.613674 [ 5117 ] {c4caeddd-5fd4-4180-9f0f-29277a45ed65} 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]:39474) (comment: 02242_join_rocksdb.sql) (query 35, line 62) (in query: SELECT * FROM t1 INNER JOIN rdb ON rdb.key + 1 == t1.k;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Planner/PlannerJoins.cpp:1283: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x00000000148e4a3c 5. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0e7d2 6. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 7. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:12:09.621316 [ 5117 ] {} TCPHandler: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Planner/PlannerJoins.cpp:1283: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x00000000148e4a3c 5. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0e7d2 6. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 7. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:12:10.166427 [ 5117 ] {5389a1d7-8d16-4be3-8c2d-9d8824655b64} 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]:39474) (comment: 02242_join_rocksdb.sql) (query 37, line 65) (in query: SELECT * FROM t1 INNER JOIN (SELECT * FROM rdb) AS rdb ON rdb.key == t1.k;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Planner/PlannerJoins.cpp:1283: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x00000000148e4a3c 5. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0e7d2 6. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 7. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:12:10.174312 [ 5117 ] {} TCPHandler: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Planner/PlannerJoins.cpp:1283: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x00000000148e4a3c 5. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0e7d2 6. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 7. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:12:10.748314 [ 5117 ] {2b2ac0fc-775b-43c3-b896-33ebf7e6fe12} 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]:39474) (comment: 02242_join_rocksdb.sql) (query 39, line 68) (in query: SELECT * FROM t1 RIGHT SEMI JOIN (SELECT * FROM rdb) AS rdb ON rdb.key == t1.k;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Planner/PlannerJoins.cpp:1283: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x00000000148e4a3c 5. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0e7d2 6. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 7. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:12:10.758293 [ 5117 ] {} TCPHandler: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Planner/PlannerJoins.cpp:1283: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x00000000148e4a3c 5. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0e7d2 6. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 7. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:12:10.965248 [ 5117 ] {7613f914-8654-4ed0-b94e-4ea6322b3123} 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]:39474) (comment: 02242_join_rocksdb.sql) (query 40, line 69) (in query: SELECT * FROM t1 RIGHT ANTI JOIN (SELECT * FROM rdb) AS rdb ON rdb.key == t1.k;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Planner/PlannerJoins.cpp:1283: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x00000000148e4a3c 5. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0e7d2 6. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 7. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:12:10.974815 [ 5117 ] {} TCPHandler: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Planner/PlannerJoins.cpp:1283: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x00000000148e4a3c 5. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0e7d2 6. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 7. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:12:11.218537 [ 16756 ] {f241d445-4a74-4108-9769-90e3b5ef9c37} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=17, jobs=0): (while reading column value1): (while reading from part /var/lib/clickhouse/store/dcc/dcce4fc2-a521-4a01-a794-dd060b59ed41/all_1_2_1_5/ in table test_13.sticking_mutations (dcce4fc2-a521-4a01-a794-dd060b59ed41) located on disk default of type local, from mark 0 with max_rows_to_read = 1874): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45968) (comment: 01415_sticking_mutations.sh) (query 1, line 1) (in query: SELECT sum(cityHash64(*)) > 1 FROM sticking_mutations WHERE key > 10), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x00000000130ebd1a 8. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:se190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x00000000130ebb0f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130eacce 10. /build/src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000130e21d0 11. /build/src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000130e24cb 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 13. /build/src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000017858cab 14. /build/src/Compression/CachedCompressedReadBuffer.cpp:52: DB::CachedCompressedReadBuffer::nextImpl() @ 0x00000000178574da 15. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 16. /build/src/IO/ReadBuffer.h:96: DB::ReadBuffer::readBig(char*, unsigned long) @ 0x000000000a08cb07 17. /build/src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000013bfcd1f 18. /build/src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000013ba04c3 19. /build/src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x00000000163b4199 20. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000163c87a0 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000163bc9b1 22. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::continueReadingChain(DB::MergeTreeRangeReader::ReadResult&, unsigned long&) @ 0x00000000163c47df 23. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:81: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x00000000163def61 24. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x00000000163dace0 25. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x0000000016d7ba8c 26. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5584 27. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 28. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 29. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 30. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 31. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 2025.07.13 02:12:11.279910 [ 16756 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=17, jobs=0): (while reading column value1): (while reading from part /var/lib/clickhouse/store/dcc/dcce4fc2-a521-4a01-a794-dd060b59ed41/all_1_2_1_5/ in table test_13.sticking_mutations (dcce4fc2-a521-4a01-a794-dd060b59ed41) located on disk default of type local, from mark 0 with max_rows_to_read = 1874): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x00000000130ebd1a 8. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:se190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x00000000130ebb0f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130eacce 10. /build/src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000130e21d0 11. /build/src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000130e24cb 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 13. /build/src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000017858cab 14. /build/src/Compression/CachedCompressedReadBuffer.cpp:52: DB::CachedCompressedReadBuffer::nextImpl() @ 0x00000000178574da 15. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 16. /build/src/IO/ReadBuffer.h:96: DB::ReadBuffer::readBig(char*, unsigned long) @ 0x000000000a08cb07 17. /build/src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000013bfcd1f 18. /build/src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000013ba04c3 19. /build/src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x00000000163b4199 20. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000163c87a0 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000163bc9b1 22. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::continueReadingChain(DB::MergeTreeRangeReader::ReadResult&, unsigned long&) @ 0x00000000163c47df 23. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:81: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x00000000163def61 24. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x00000000163dace0 25. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x0000000016d7ba8c 26. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5584 27. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 28. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 29. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 30. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 31. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:12:11.796348 [ 5998 ] {4b4df4f6-6b1a-4d2e-ad5d-d0294d67b8bd} executeQuery: Code: 469. DB::Exception: Constraint `_implicit_sign_column_constraint` for table test_15.versioned_collapsing_merge_tree_2 (deeed04b-6aa1-4c83-9cef-2f7c3807997c) is violated at row 1. Expression: (Sign IN [-1, 1]). Column values: Sign = 5. (VIOLATED_CONSTRAINT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45992) (comment: 02918_implicit_sign_column_constraints_for_collapsing_engine.sh) (query 1, line 1) (in query: INSERT INTO versioned_collapsing_merge_tree_2 VALUES ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&) @ 0x0000000013bf7039 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000016b2113c 5. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 7. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 10. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 11. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000168e3c3f 12. /build/src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001681130c 13. /build/src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x0000000016806e9c 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:12:11.818393 [ 5998 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `_implicit_sign_column_constraint` for table test_15.versioned_collapsing_merge_tree_2 (deeed04b-6aa1-4c83-9cef-2f7c3807997c) is violated at row 1. Expression: (Sign IN [-1, 1]). Column values: Sign = 5. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&) @ 0x0000000013bf7039 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000016b2113c 5. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 7. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 10. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 11. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000168e3c3f 12. /build/src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001681130c 13. /build/src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x0000000016806e9c 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:12:12.377356 [ 3542 ] {f76f4233-22c7-4d02-98ad-4390bbcd535d} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39324) (comment: 01910_view_dictionary_check_refresh.sql) (query 17, line 51) (in query: DROP DICTIONARY IF EXISTS TestTblDict;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833ede 5. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 7. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 10. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:12:12.406086 [ 3542 ] {} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833ede 5. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 7. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 10. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:12:13.095581 [ 5821 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:12:13.704377 [ 16758 ] {499b2ad7-3967-4554-8d76-3fafef4991dd} executeQuery: Code: 6. DB::Exception: Cannot parse string 'x123' as Decimal(9, 4): syntax error at begin of string: In scope SELECT toDecimal32('x123', 4). (CANNOT_PARSE_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46028) (comment: 00700_to_decimal_or_something_1.gen.sql) (query 4, line 4) (in query: SELECT toDecimal32 ('x123', 4);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: 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) @ 0x0000000012ffbd57 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x0000000012ffb99e 6. /build/src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x0000000012fea844 7. /build/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&&) @ 0x0000000012e97aa1 8. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eb8d8e 9. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eb85ba 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 31. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 2025.07.13 02:12:13.733728 [ 16758 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string 'x123' as Decimal(9, 4): syntax error at begin of string: In scope SELECT toDecimal32('x123', 4). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: 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) @ 0x0000000012ffbd57 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x0000000012ffb99e 6. /build/src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x0000000012fea844 7. /build/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&&) @ 0x0000000012e97aa1 8. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eb8d8e 9. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eb85ba 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 31. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 2025.07.13 02:12:14.049953 [ 16758 ] {a7552e6c-34bd-43b7-a4cc-ba9aa3bd5fb0} executeQuery: Code: 32. DB::Exception: Attempt to read after eof: Cannot parse Decimal(9, 4) from String, because value is too short: In scope SELECT toDecimal32('', 4). (ATTEMPT_TO_READ_AFTER_EOF) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46028) (comment: 00700_to_decimal_or_something_1.gen.sql) (query 5, line 5) (in query: SELECT toDecimal32 ('', 4);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/IO/VarInt.cpp:13: DB::throwReadAfterEOF() @ 0x000000000fb986db 5. /build/src/IO/readDecimalText.h:35: bool DB::readDigits>(DB::ReadBuffer&, DB::Decimal&, unsigned int&, int&, bool) @ 0x00000000138a033f 6. /build/src/IO/readDecimalText.h:154: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x0000000013b5a58a 7. /build/src/DataTypes/Serializations/SerializationDecimal.cpp:46: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x0000000013bb680d 8. /build/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) @ 0x0000000012ffbc81 9. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x0000000012ffb99e 10. /build/src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x0000000012fea844 11. /build/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&&) @ 0x0000000012e97aa1 12. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eb8d8e 13. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eb85ba 14. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 15. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 16. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 17. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 18. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 19. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 20. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 27. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 28. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 2025.07.13 02:12:14.063609 [ 16758 ] {} TCPHandler: Code: 32. DB::Exception: Attempt to read after eof: Cannot parse Decimal(9, 4) from String, because value is too short: In scope SELECT toDecimal32('', 4). (ATTEMPT_TO_READ_AFTER_EOF), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/IO/VarInt.cpp:13: DB::throwReadAfterEOF() @ 0x000000000fb986db 5. /build/src/IO/readDecimalText.h:35: bool DB::readDigits>(DB::ReadBuffer&, DB::Decimal&, unsigned int&, int&, bool) @ 0x00000000138a033f 6. /build/src/IO/readDecimalText.h:154: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x0000000013b5a58a 7. /build/src/DataTypes/Serializations/SerializationDecimal.cpp:46: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x0000000013bb680d 8. /build/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) @ 0x0000000012ffbc81 9. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x0000000012ffb99e 10. /build/src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x0000000012fea844 11. /build/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&&) @ 0x0000000012e97aa1 12. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eb8d8e 13. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eb85ba 14. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 15. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 16. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 17. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 18. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 19. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 20. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 27. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 28. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 2025.07.13 02:12:14.147908 [ 16758 ] {e418e9d3-9433-4f72-a3c5-aac2c81b69f3} executeQuery: Code: 6. DB::Exception: Cannot parse string '\0' as Decimal(9, 4): syntax error at begin of string: In scope SELECT toDecimal32('\0', 4). (CANNOT_PARSE_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46028) (comment: 00700_to_decimal_or_something_1.gen.sql) (query 6, line 6) (in query: SELECT toDecimal32 ('\0', 4);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: 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) @ 0x0000000012ffbd57 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x0000000012ffb99e 6. /build/src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x0000000012fea844 7. /build/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&&) @ 0x0000000012e97aa1 8. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eb8d8e 9. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eb85ba 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 31. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 2025.07.13 02:12:14.160522 [ 16758 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '\0' as Decimal(9, 4): syntax error at begin of string: In scope SELECT toDecimal32('\0', 4). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: 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) @ 0x0000000012ffbd57 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x0000000012ffb99e 6. /build/src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x0000000012fea844 7. /build/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&&) @ 0x0000000012e97aa1 8. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eb8d8e 9. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eb85ba 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 31. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 2025.07.13 02:12:14.274211 [ 16758 ] {09b3131a-6c04-49ca-840c-0fd4e6f1d042} executeQuery: Code: 6. DB::Exception: Cannot parse string '\0\0\0\0\0' as Decimal(9, 4): syntax error at begin of string: In scope SELECT toDecimal32('\0\0\0\0\0', 4). (CANNOT_PARSE_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46028) (comment: 00700_to_decimal_or_something_1.gen.sql) (query 7, line 7) (in query: SELECT toDecimal32 ('\0\0\0\0\0', 4);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: 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) @ 0x0000000012ffbd57 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x0000000012ffb99e 6. /build/src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x0000000012fea844 7. /build/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&&) @ 0x0000000012e97aa1 8. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eb8d8e 9. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eb85ba 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 31. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 2025.07.13 02:12:14.313907 [ 16758 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '\0\0\0\0\0' as Decimal(9, 4): syntax error at begin of string: In scope SELECT toDecimal32('\0\0\0\0\0', 4). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: 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) @ 0x0000000012ffbd57 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x0000000012ffb99e 6. /build/src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x0000000012fea844 7. /build/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&&) @ 0x0000000012e97aa1 8. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eb8d8e 9. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eb85ba 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 31. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 2025.07.13 02:12:14.422560 [ 16758 ] {b42b0568-0e6f-48ed-801d-61af72cc0710} executeQuery: Code: 6. DB::Exception: Cannot parse string '\n\t\r' as Decimal(9, 4): syntax error at begin of string: In scope SELECT toDecimal32('\n\t\r', 4). (CANNOT_PARSE_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46028) (comment: 00700_to_decimal_or_something_1.gen.sql) (query 8, line 8) (in query: SELECT toDecimal32 ('\n\t\r', 4);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: 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) @ 0x0000000012ffbd57 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x0000000012ffb99e 6. /build/src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x0000000012fea844 7. /build/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&&) @ 0x0000000012e97aa1 8. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eb8d8e 9. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eb85ba 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 31. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 2025.07.13 02:12:14.447544 [ 16758 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '\n\t\r' as Decimal(9, 4): syntax error at begin of string: In scope SELECT toDecimal32('\n\t\r', 4). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: 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) @ 0x0000000012ffbd57 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x0000000012ffb99e 6. /build/src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x0000000012fea844 7. /build/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&&) @ 0x0000000012e97aa1 8. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eb8d8e 9. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eb85ba 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 31. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 2025.07.13 02:12:14.559283 [ 16758 ] {c95c44ca-5a4a-47ad-8349-8909e173a86a} executeQuery: Code: 6. DB::Exception: Cannot parse string '\'' as Decimal(9, 4): syntax error at begin of string: In scope SELECT toDecimal32('\'', 4). (CANNOT_PARSE_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46028) (comment: 00700_to_decimal_or_something_1.gen.sql) (query 9, line 9) (in query: SELECT toDecimal32 ('\'', 4);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: 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) @ 0x0000000012ffbd57 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x0000000012ffb99e 6. /build/src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x0000000012fea844 7. /build/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&&) @ 0x0000000012e97aa1 8. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eb8d8e 9. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eb85ba 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 31. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 2025.07.13 02:12:14.585551 [ 16758 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '\'' as Decimal(9, 4): syntax error at begin of string: In scope SELECT toDecimal32('\'', 4). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: 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) @ 0x0000000012ffbd57 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x0000000012ffb99e 6. /build/src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x0000000012fea844 7. /build/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&&) @ 0x0000000012e97aa1 8. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eb8d8e 9. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eb85ba 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 31. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 2025.07.13 02:12:14.640978 [ 27539 ] {517e6f87-e13a-4755-8d0c-e096be5b1860} 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]:46044) (comment: 02479_analyzer_join_with_constants.sql) (query 6, line 11) (in query: SELECT * FROM (SELECT 1 AS id) AS t1 INNER JOIN (SELECT 1 AS id) AS t2 ON t1.id = t2.id AND 0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/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&) @ 0x00000000148d464b 5. /build/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&) @ 0x00000000148afcbb 6. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 7. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 9. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:12:14.656156 [ 27539 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/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&) @ 0x00000000148d464b 5. /build/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&) @ 0x00000000148afcbb 6. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 7. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 9. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:12:15.621899 [ 16756 ] {7b6bbd51-d656-4827-be6b-6a79f8e5b93f} executeQuery: Code: 36. DB::Exception: From array size and to array size mismatch: In scope SELECT bitmapTransform(arrayReduce('groupBitmapState', [1]), [1, 2], [1, 2, 3]). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46082) (comment: 02430_bitmap_transform_exception_code.sql) (query 1, line 1) (in query: SELECT bitmapTransform(arrayReduce('groupBitmapState', [1]), [1, 2], [1, 2, 3]);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/FunctionsBitmap.h:655: COW::immutable_ptr DB::FunctionBitmapTransform::executeIntType(std::vector> const&, unsigned long) const @ 0x000000000a01084e 5. /build/src/Functions/FunctionsBitmap.h:547: DB::FunctionBitmapTransform::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a00f89d 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:12:15.638100 [ 16756 ] {} TCPHandler: Code: 36. DB::Exception: From array size and to array size mismatch: In scope SELECT bitmapTransform(arrayReduce('groupBitmapState', [1]), [1, 2], [1, 2, 3]). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/FunctionsBitmap.h:655: COW::immutable_ptr DB::FunctionBitmapTransform::executeIntType(std::vector> const&, unsigned long) const @ 0x000000000a01084e 5. /build/src/Functions/FunctionsBitmap.h:547: DB::FunctionBitmapTransform::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a00f89d 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:12:15.766274 [ 16758 ] {2cccab3a-abcd-4dc6-9d95-36aac9fcca43} executeQuery: Code: 6. DB::Exception: Cannot parse string 'x123' as Decimal(18, 4): syntax error at begin of string: In scope SELECT toDecimal64('x123', 4). (CANNOT_PARSE_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46028) (comment: 00700_to_decimal_or_something_1.gen.sql) (query 13, line 14) (in query: SELECT toDecimal64 ('x123', 4);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing>, DB::detail::NameToDecimal64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000130143b7 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl>, DB::detail::NameToDecimal64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x0000000013013ffe 6. /build/src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x0000000013002f64 7. /build/src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e97da1 8. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eba14e 9. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eb997a 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 31. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 2025.07.13 02:12:15.778430 [ 16758 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string 'x123' as Decimal(18, 4): syntax error at begin of string: In scope SELECT toDecimal64('x123', 4). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing>, DB::detail::NameToDecimal64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000130143b7 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl>, DB::detail::NameToDecimal64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x0000000013013ffe 6. /build/src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x0000000013002f64 7. /build/src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e97da1 8. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eba14e 9. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eb997a 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 31. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 2025.07.13 02:12:16.309973 [ 16758 ] {332a10ef-bb9f-4ac6-94f8-44f75ce52890} executeQuery: Code: 32. DB::Exception: Attempt to read after eof: Cannot parse Decimal(18, 4) from String, because value is too short: In scope SELECT toDecimal64('', 4). (ATTEMPT_TO_READ_AFTER_EOF) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46028) (comment: 00700_to_decimal_or_something_1.gen.sql) (query 14, line 15) (in query: SELECT toDecimal64 ('', 4);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/IO/VarInt.cpp:13: DB::throwReadAfterEOF() @ 0x000000000fb986db 5. /build/src/IO/readDecimalText.h:35: bool DB::readDigits>(DB::ReadBuffer&, DB::Decimal&, unsigned int&, int&, bool) @ 0x00000000138a096d 6. /build/src/IO/readDecimalText.h:154: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x0000000013b5a9ea 7. /build/src/DataTypes/Serializations/SerializationDecimal.cpp:46: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x0000000013bb734d 8. /build/src/Functions/FunctionsConversion.h:1014: COW::immutable_ptr DB::detail::ConvertThroughParsing>, DB::detail::NameToDecimal64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000130142e1 9. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl>, DB::detail::NameToDecimal64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x0000000013013ffe 10. /build/src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x0000000013002f64 11. /build/src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e97da1 12. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eba14e 13. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eb997a 14. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 15. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 16. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 17. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 18. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 19. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 20. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 27. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 28. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 2025.07.13 02:12:16.336500 [ 16758 ] {} TCPHandler: Code: 32. DB::Exception: Attempt to read after eof: Cannot parse Decimal(18, 4) from String, because value is too short: In scope SELECT toDecimal64('', 4). (ATTEMPT_TO_READ_AFTER_EOF), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/IO/VarInt.cpp:13: DB::throwReadAfterEOF() @ 0x000000000fb986db 5. /build/src/IO/readDecimalText.h:35: bool DB::readDigits>(DB::ReadBuffer&, DB::Decimal&, unsigned int&, int&, bool) @ 0x00000000138a096d 6. /build/src/IO/readDecimalText.h:154: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x0000000013b5a9ea 7. /build/src/DataTypes/Serializations/SerializationDecimal.cpp:46: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x0000000013bb734d 8. /build/src/Functions/FunctionsConversion.h:1014: COW::immutable_ptr DB::detail::ConvertThroughParsing>, DB::detail::NameToDecimal64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000130142e1 9. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl>, DB::detail::NameToDecimal64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x0000000013013ffe 10. /build/src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x0000000013002f64 11. /build/src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e97da1 12. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eba14e 13. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eb997a 14. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 15. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 16. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 17. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 18. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 19. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 20. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 27. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 28. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 2025.07.13 02:12:16.401040 [ 16758 ] {26931fad-d665-4c8f-83ae-0cfbf51966fa} executeQuery: Code: 6. DB::Exception: Cannot parse string '\0' as Decimal(18, 4): syntax error at begin of string: In scope SELECT toDecimal64('\0', 4). (CANNOT_PARSE_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46028) (comment: 00700_to_decimal_or_something_1.gen.sql) (query 15, line 16) (in query: SELECT toDecimal64 ('\0', 4);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing>, DB::detail::NameToDecimal64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000130143b7 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl>, DB::detail::NameToDecimal64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x0000000013013ffe 6. /build/src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x0000000013002f64 7. /build/src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e97da1 8. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eba14e 9. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eb997a 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 31. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 2025.07.13 02:12:16.412309 [ 16758 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '\0' as Decimal(18, 4): syntax error at begin of string: In scope SELECT toDecimal64('\0', 4). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing>, DB::detail::NameToDecimal64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000130143b7 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl>, DB::detail::NameToDecimal64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x0000000013013ffe 6. /build/src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x0000000013002f64 7. /build/src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e97da1 8. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eba14e 9. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eb997a 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 31. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 2025.07.13 02:12:16.505647 [ 16758 ] {ef062943-06fe-449f-9240-e964b8d1f718} executeQuery: Code: 6. DB::Exception: Cannot parse string '\0\0\0\0\0' as Decimal(18, 4): syntax error at begin of string: In scope SELECT toDecimal64('\0\0\0\0\0', 4). (CANNOT_PARSE_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46028) (comment: 00700_to_decimal_or_something_1.gen.sql) (query 16, line 17) (in query: SELECT toDecimal64 ('\0\0\0\0\0', 4);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing>, DB::detail::NameToDecimal64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000130143b7 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl>, DB::detail::NameToDecimal64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x0000000013013ffe 6. /build/src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x0000000013002f64 7. /build/src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e97da1 8. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eba14e 9. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eb997a 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 31. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 2025.07.13 02:12:16.513901 [ 16758 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '\0\0\0\0\0' as Decimal(18, 4): syntax error at begin of string: In scope SELECT toDecimal64('\0\0\0\0\0', 4). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing>, DB::detail::NameToDecimal64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000130143b7 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl>, DB::detail::NameToDecimal64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x0000000013013ffe 6. /build/src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x0000000013002f64 7. /build/src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e97da1 8. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eba14e 9. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eb997a 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 31. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 2025.07.13 02:12:16.620071 [ 16758 ] {d2d8894f-70a8-4570-9a94-e34c5a6d5dd3} executeQuery: Code: 6. DB::Exception: Cannot parse string '\n\t\r' as Decimal(18, 4): syntax error at begin of string: In scope SELECT toDecimal64('\n\t\r', 4). (CANNOT_PARSE_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46028) (comment: 00700_to_decimal_or_something_1.gen.sql) (query 17, line 18) (in query: SELECT toDecimal64 ('\n\t\r', 4);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing>, DB::detail::NameToDecimal64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000130143b7 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl>, DB::detail::NameToDecimal64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x0000000013013ffe 6. /build/src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x0000000013002f64 7. /build/src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e97da1 8. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eba14e 9. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eb997a 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 31. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 2025.07.13 02:12:16.628065 [ 16758 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '\n\t\r' as Decimal(18, 4): syntax error at begin of string: In scope SELECT toDecimal64('\n\t\r', 4). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing>, DB::detail::NameToDecimal64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000130143b7 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl>, DB::detail::NameToDecimal64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x0000000013013ffe 6. /build/src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x0000000013002f64 7. /build/src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e97da1 8. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eba14e 9. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eb997a 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 31. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 2025.07.13 02:12:16.776149 [ 16758 ] {97df1f43-b982-4401-98e2-5f8e83390047} executeQuery: Code: 6. DB::Exception: Cannot parse string '\'' as Decimal(18, 4): syntax error at begin of string: In scope SELECT toDecimal64('\'', 4). (CANNOT_PARSE_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46028) (comment: 00700_to_decimal_or_something_1.gen.sql) (query 18, line 19) (in query: SELECT toDecimal64 ('\'', 4);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing>, DB::detail::NameToDecimal64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000130143b7 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl>, DB::detail::NameToDecimal64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x0000000013013ffe 6. /build/src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x0000000013002f64 7. /build/src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e97da1 8. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eba14e 9. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eb997a 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 31. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 2025.07.13 02:12:16.818364 [ 16758 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '\'' as Decimal(18, 4): syntax error at begin of string: In scope SELECT toDecimal64('\'', 4). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing>, DB::detail::NameToDecimal64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000130143b7 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl>, DB::detail::NameToDecimal64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x0000000013013ffe 6. /build/src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x0000000013002f64 7. /build/src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e97da1 8. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eba14e 9. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eb997a 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 31. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 2025.07.13 02:12:17.608356 [ 3543 ] {94303805-b376-400c-931d-65617aec639e} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 54.01 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]:39404) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000000fb2de96 4. /build/src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2ca0a 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2c5bf 6. /build/src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000fa9410c 7. /build/src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000000fa92c7f 8. /build/src/Common/PODArray.h:152: void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000009fb12b7 9. /build/src/Columns/ColumnVector.cpp:530: DB::ColumnVector::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x0000000015a89d7d 10. /build/src/Columns/IColumn.h:210: DB::(anonymous namespace)::copyLeftRange(DB::Block const&, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, unsigned long, unsigned long) @ 0x000000001492d77b 11. /build/src/Interpreters/MergeJoin.cpp:445: 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&) @ 0x000000001492bc95 12. /build/src/Interpreters/MergeJoin.cpp:845: void DB::MergeJoin::joinSortedBlock(DB::Block&, std::shared_ptr&) @ 0x000000001492e4e3 13. /build/src/Interpreters/MergeJoin.cpp:742: DB::MergeJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x000000001492b464 14. /build/src/Processors/Transforms/JoiningTransform.cpp:238: DB::JoiningTransform::readExecute(DB::Chunk&)::$_0::operator()() const @ 0x0000000016b39bff 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::JoiningTransform::readExecute(DB::Chunk&) @ 0x0000000016b39a03 16. /build/src/Processors/Transforms/JoiningTransform.cpp:207: DB::JoiningTransform::transform(DB::Chunk&) @ 0x0000000016b38bbd 17. /build/src/Processors/Transforms/JoiningTransform.cpp:137: DB::JoiningTransform::work() @ 0x0000000016b387b5 18. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 19. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 20. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 21. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 22. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 23. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 25. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:12:17.666326 [ 3543 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 54.01 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000000fb2de96 4. /build/src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2ca0a 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2c5bf 6. /build/src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000fa9410c 7. /build/src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000000fa92c7f 8. /build/src/Common/PODArray.h:152: void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000009fb12b7 9. /build/src/Columns/ColumnVector.cpp:530: DB::ColumnVector::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x0000000015a89d7d 10. /build/src/Columns/IColumn.h:210: DB::(anonymous namespace)::copyLeftRange(DB::Block const&, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, unsigned long, unsigned long) @ 0x000000001492d77b 11. /build/src/Interpreters/MergeJoin.cpp:445: 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&) @ 0x000000001492bc95 12. /build/src/Interpreters/MergeJoin.cpp:845: void DB::MergeJoin::joinSortedBlock(DB::Block&, std::shared_ptr&) @ 0x000000001492e4e3 13. /build/src/Interpreters/MergeJoin.cpp:742: DB::MergeJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x000000001492b464 14. /build/src/Processors/Transforms/JoiningTransform.cpp:238: DB::JoiningTransform::readExecute(DB::Chunk&)::$_0::operator()() const @ 0x0000000016b39bff 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::JoiningTransform::readExecute(DB::Chunk&) @ 0x0000000016b39a03 16. /build/src/Processors/Transforms/JoiningTransform.cpp:207: DB::JoiningTransform::transform(DB::Chunk&) @ 0x0000000016b38bbd 17. /build/src/Processors/Transforms/JoiningTransform.cpp:137: DB::JoiningTransform::work() @ 0x0000000016b387b5 18. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 19. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 20. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 21. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 22. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 23. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 25. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:12:17.972976 [ 16758 ] {8b8472c3-6670-4cdc-abd2-bd908a250981} executeQuery: Code: 6. DB::Exception: Cannot parse string 'x123' as Decimal(38, 4): syntax error at begin of string: In scope SELECT toDecimal128('x123', 4). (CANNOT_PARSE_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46028) (comment: 00700_to_decimal_or_something_1.gen.sql) (query 22, line 24) (in query: SELECT toDecimal128 ('x123', 4);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing>>, DB::detail::NameToDecimal128, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001302d137 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::detail::NameToDecimal128, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000001302cd7e 6. /build/src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000001301b5c4 7. /build/src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>>, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e980a1 8. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ebb50e 9. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ebad3a 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 31. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 2025.07.13 02:12:17.983246 [ 16758 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string 'x123' as Decimal(38, 4): syntax error at begin of string: In scope SELECT toDecimal128('x123', 4). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing>>, DB::detail::NameToDecimal128, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001302d137 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::detail::NameToDecimal128, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000001302cd7e 6. /build/src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000001301b5c4 7. /build/src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>>, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e980a1 8. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ebb50e 9. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ebad3a 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 31. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 2025.07.13 02:12:18.229733 [ 3543 ] {170ee2eb-2e5b-4470-86e4-2ec77261d9fd} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 50.03 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]:39404) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000000fb2de96 4. /build/src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2ca0a 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2c5bf 6. /build/src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000fa9410c 7. /build/src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000000fa92c7f 8. /build/src/Common/PODArray.h:152: void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000009fb12b7 9. /build/src/Columns/ColumnVector.cpp:530: DB::ColumnVector::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x0000000015a89d7d 10. /build/src/Columns/IColumn.h:210: DB::(anonymous namespace)::copyLeftRange(DB::Block const&, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, unsigned long, unsigned long) @ 0x000000001492d77b 11. /build/src/Interpreters/MergeJoin.cpp:445: 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&) @ 0x000000001492bc95 12. /build/src/Interpreters/MergeJoin.cpp:845: void DB::MergeJoin::joinSortedBlock(DB::Block&, std::shared_ptr&) @ 0x000000001492e4e3 13. /build/src/Interpreters/MergeJoin.cpp:742: DB::MergeJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x000000001492b464 14. /build/src/Processors/Transforms/JoiningTransform.cpp:238: DB::JoiningTransform::readExecute(DB::Chunk&)::$_0::operator()() const @ 0x0000000016b39bff 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::JoiningTransform::readExecute(DB::Chunk&) @ 0x0000000016b39a03 16. /build/src/Processors/Transforms/JoiningTransform.cpp:207: DB::JoiningTransform::transform(DB::Chunk&) @ 0x0000000016b38bbd 17. /build/src/Processors/Transforms/JoiningTransform.cpp:137: DB::JoiningTransform::work() @ 0x0000000016b387b5 18. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 19. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 20. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 21. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 22. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 23. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 25. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:12:18.231602 [ 16758 ] {3e8694b8-68db-4d6b-bc80-913f11fd5c91} executeQuery: Code: 32. DB::Exception: Attempt to read after eof: Cannot parse Decimal(38, 4) from String, because value is too short: In scope SELECT toDecimal128('', 4). (ATTEMPT_TO_READ_AFTER_EOF) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46028) (comment: 00700_to_decimal_or_something_1.gen.sql) (query 23, line 25) (in query: SELECT toDecimal128 ('', 4);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/IO/VarInt.cpp:13: DB::throwReadAfterEOF() @ 0x000000000fb986db 5. /build/src/IO/readDecimalText.h:35: bool DB::readDigits>>(DB::ReadBuffer&, DB::Decimal>&, unsigned int&, int&, bool) @ 0x00000000138a0fd2 6. /build/src/IO/readDecimalText.h:154: void DB::readDecimalText>, void>(DB::ReadBuffer&, DB::Decimal>&, unsigned int, unsigned int&, bool) @ 0x0000000013b5ae0a 7. /build/src/DataTypes/Serializations/SerializationDecimal.cpp:46: DB::SerializationDecimal>>::readText(DB::Decimal>&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x0000000013bb7feb 8. /build/src/Functions/FunctionsConversion.h:1014: COW::immutable_ptr DB::detail::ConvertThroughParsing>>, DB::detail::NameToDecimal128, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001302d061 9. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::detail::NameToDecimal128, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000001302cd7e 10. /build/src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000001301b5c4 11. /build/src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>>, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e980a1 12. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ebb50e 13. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ebad3a 14. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 15. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 16. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 17. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 18. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 19. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 20. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 27. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 28. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 2025.07.13 02:12:18.245204 [ 3543 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 50.03 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000000fb2de96 4. /build/src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2ca0a 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2c5bf 6. /build/src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000fa9410c 7. /build/src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000000fa92c7f 8. /build/src/Common/PODArray.h:152: void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000009fb12b7 9. /build/src/Columns/ColumnVector.cpp:530: DB::ColumnVector::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x0000000015a89d7d 10. /build/src/Columns/IColumn.h:210: DB::(anonymous namespace)::copyLeftRange(DB::Block const&, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, unsigned long, unsigned long) @ 0x000000001492d77b 11. /build/src/Interpreters/MergeJoin.cpp:445: 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&) @ 0x000000001492bc95 12. /build/src/Interpreters/MergeJoin.cpp:845: void DB::MergeJoin::joinSortedBlock(DB::Block&, std::shared_ptr&) @ 0x000000001492e4e3 13. /build/src/Interpreters/MergeJoin.cpp:742: DB::MergeJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x000000001492b464 14. /build/src/Processors/Transforms/JoiningTransform.cpp:238: DB::JoiningTransform::readExecute(DB::Chunk&)::$_0::operator()() const @ 0x0000000016b39bff 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::JoiningTransform::readExecute(DB::Chunk&) @ 0x0000000016b39a03 16. /build/src/Processors/Transforms/JoiningTransform.cpp:207: DB::JoiningTransform::transform(DB::Chunk&) @ 0x0000000016b38bbd 17. /build/src/Processors/Transforms/JoiningTransform.cpp:137: DB::JoiningTransform::work() @ 0x0000000016b387b5 18. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 19. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 20. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 21. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 22. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 23. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 25. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:12:18.245367 [ 5081 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:12:18.251696 [ 16758 ] {} TCPHandler: Code: 32. DB::Exception: Attempt to read after eof: Cannot parse Decimal(38, 4) from String, because value is too short: In scope SELECT toDecimal128('', 4). (ATTEMPT_TO_READ_AFTER_EOF), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/IO/VarInt.cpp:13: DB::throwReadAfterEOF() @ 0x000000000fb986db 5. /build/src/IO/readDecimalText.h:35: bool DB::readDigits>>(DB::ReadBuffer&, DB::Decimal>&, unsigned int&, int&, bool) @ 0x00000000138a0fd2 6. /build/src/IO/readDecimalText.h:154: void DB::readDecimalText>, void>(DB::ReadBuffer&, DB::Decimal>&, unsigned int, unsigned int&, bool) @ 0x0000000013b5ae0a 7. /build/src/DataTypes/Serializations/SerializationDecimal.cpp:46: DB::SerializationDecimal>>::readText(DB::Decimal>&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x0000000013bb7feb 8. /build/src/Functions/FunctionsConversion.h:1014: COW::immutable_ptr DB::detail::ConvertThroughParsing>>, DB::detail::NameToDecimal128, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001302d061 9. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::detail::NameToDecimal128, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000001302cd7e 10. /build/src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000001301b5c4 11. /build/src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>>, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e980a1 12. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ebb50e 13. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ebad3a 14. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 15. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 16. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 17. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 18. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 19. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 20. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 27. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 28. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 2025.07.13 02:12:18.423905 [ 16758 ] {4368e858-14aa-442a-b8c8-0c011fe2f8c9} executeQuery: Code: 6. DB::Exception: Cannot parse string '\0' as Decimal(38, 4): syntax error at begin of string: In scope SELECT toDecimal128('\0', 4). (CANNOT_PARSE_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46028) (comment: 00700_to_decimal_or_something_1.gen.sql) (query 24, line 26) (in query: SELECT toDecimal128 ('\0', 4);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing>>, DB::detail::NameToDecimal128, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001302d137 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::detail::NameToDecimal128, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000001302cd7e 6. /build/src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000001301b5c4 7. /build/src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>>, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e980a1 8. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ebb50e 9. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ebad3a 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 31. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 2025.07.13 02:12:18.433110 [ 16758 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '\0' as Decimal(38, 4): syntax error at begin of string: In scope SELECT toDecimal128('\0', 4). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing>>, DB::detail::NameToDecimal128, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001302d137 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::detail::NameToDecimal128, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000001302cd7e 6. /build/src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000001301b5c4 7. /build/src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>>, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e980a1 8. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ebb50e 9. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ebad3a 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 31. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 2025.07.13 02:12:18.523426 [ 16758 ] {e77a86a1-4e9a-43bf-869d-8dadd9afda13} executeQuery: Code: 6. DB::Exception: Cannot parse string '\0\0\0\0\0' as Decimal(38, 4): syntax error at begin of string: In scope SELECT toDecimal128('\0\0\0\0\0', 4). (CANNOT_PARSE_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46028) (comment: 00700_to_decimal_or_something_1.gen.sql) (query 25, line 27) (in query: SELECT toDecimal128 ('\0\0\0\0\0', 4);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing>>, DB::detail::NameToDecimal128, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001302d137 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::detail::NameToDecimal128, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000001302cd7e 6. /build/src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000001301b5c4 7. /build/src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>>, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e980a1 8. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ebb50e 9. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ebad3a 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 31. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 2025.07.13 02:12:18.536781 [ 16758 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '\0\0\0\0\0' as Decimal(38, 4): syntax error at begin of string: In scope SELECT toDecimal128('\0\0\0\0\0', 4). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing>>, DB::detail::NameToDecimal128, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001302d137 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::detail::NameToDecimal128, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000001302cd7e 6. /build/src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000001301b5c4 7. /build/src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>>, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e980a1 8. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ebb50e 9. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ebad3a 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 31. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 2025.07.13 02:12:18.673359 [ 16758 ] {5dd18800-cd65-4f0e-a1ef-7150bff978a3} executeQuery: Code: 6. DB::Exception: Cannot parse string '\n\t\r' as Decimal(38, 4): syntax error at begin of string: In scope SELECT toDecimal128('\n\t\r', 4). (CANNOT_PARSE_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46028) (comment: 00700_to_decimal_or_something_1.gen.sql) (query 26, line 28) (in query: SELECT toDecimal128 ('\n\t\r', 4);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing>>, DB::detail::NameToDecimal128, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001302d137 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::detail::NameToDecimal128, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000001302cd7e 6. /build/src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000001301b5c4 7. /build/src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>>, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e980a1 8. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ebb50e 9. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ebad3a 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 31. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 2025.07.13 02:12:18.681514 [ 16758 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '\n\t\r' as Decimal(38, 4): syntax error at begin of string: In scope SELECT toDecimal128('\n\t\r', 4). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing>>, DB::detail::NameToDecimal128, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001302d137 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::detail::NameToDecimal128, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000001302cd7e 6. /build/src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000001301b5c4 7. /build/src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>>, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e980a1 8. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ebb50e 9. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ebad3a 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 31. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 2025.07.13 02:12:18.756168 [ 16758 ] {dee541dd-5c62-4931-8846-d712f03b6be4} executeQuery: Code: 6. DB::Exception: Cannot parse string '\'' as Decimal(38, 4): syntax error at begin of string: In scope SELECT toDecimal128('\'', 4). (CANNOT_PARSE_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46028) (comment: 00700_to_decimal_or_something_1.gen.sql) (query 27, line 29) (in query: SELECT toDecimal128 ('\'', 4);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing>>, DB::detail::NameToDecimal128, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001302d137 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::detail::NameToDecimal128, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000001302cd7e 6. /build/src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000001301b5c4 7. /build/src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>>, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e980a1 8. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ebb50e 9. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ebad3a 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 31. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 2025.07.13 02:12:18.770530 [ 16758 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '\'' as Decimal(38, 4): syntax error at begin of string: In scope SELECT toDecimal128('\'', 4). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing>>, DB::detail::NameToDecimal128, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001302d137 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::detail::NameToDecimal128, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000001302cd7e 6. /build/src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000001301b5c4 7. /build/src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>>, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e980a1 8. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ebb50e 9. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ebad3a 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 31. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 2025.07.13 02:12:19.672994 [ 16758 ] {3c5b9878-10ca-4ba6-a442-845a355951a9} executeQuery: Code: 6. DB::Exception: Cannot parse string 'x123' as Decimal(76, 4): syntax error at begin of string: In scope SELECT toDecimal256('x123', 4). (CANNOT_PARSE_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46028) (comment: 00700_to_decimal_or_something_1.gen.sql) (query 31, line 34) (in query: SELECT toDecimal256 ('x123', 4);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing>>, DB::detail::NameToDecimal256, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000013046757 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::detail::NameToDecimal256, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000001304639e 6. /build/src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>>, DB::detail::NameToDecimal256, 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 @ 0x00000000130343a4 7. /build/src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>>, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal256, 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::NameToDecimal256, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e983a1 8. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal256, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ebc8ce 9. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal256, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ebc0fa 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 31. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 2025.07.13 02:12:19.681355 [ 16758 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string 'x123' as Decimal(76, 4): syntax error at begin of string: In scope SELECT toDecimal256('x123', 4). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing>>, DB::detail::NameToDecimal256, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000013046757 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::detail::NameToDecimal256, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000001304639e 6. /build/src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>>, DB::detail::NameToDecimal256, 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 @ 0x00000000130343a4 7. /build/src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>>, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal256, 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::NameToDecimal256, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e983a1 8. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal256, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ebc8ce 9. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal256, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ebc0fa 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 31. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 2025.07.13 02:12:19.701515 [ 16756 ] {17d87827-352f-4ddc-92c2-b5fd7e7fe904} executeQuery: Code: 407. DB::Exception: Numeric overflow: In scope SELECT toStartOfInterval(toDateTime64('\0930-12-12 12:12:12.1234567', 3), toIntervalNanosecond(1024)). (DECIMAL_OVERFLOW) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42436) (comment: 02269_to_start_of_interval_overflow.sql) (query 1, line 1) (in query: select toStartOfInterval(toDateTime64('\0930-12-12 12:12:12.1234567', 3), toIntervalNanosecond(1024));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/DateTimeTransforms.h:504: DB::ToStartOfInterval<(DB::IntervalKind::Kind)0>::execute(long, long, DateLUTImpl const&, long, long) @ 0x000000000e7a173f 5. /build/src/Functions/toStartOfInterval.cpp:423: COW::immutable_ptr DB::FunctionToStartOfInterval::execute, (DB::IntervalKind::Kind)0>(DB::DataTypeDateTime64 const&, DB::ColumnDecimal const&, long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e7ce4a1 6. /build/src/Functions/toStartOfInterval.cpp:329: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDateTime64 const&, DB::ColumnDecimal const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e7c55bc 7. /build/src/Functions/toStartOfInterval.cpp:286: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e79c9c3 8. /build/src/Functions/toStartOfInterval.cpp:249: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e79b630 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:12:19.714726 [ 16756 ] {} TCPHandler: Code: 407. DB::Exception: Numeric overflow: In scope SELECT toStartOfInterval(toDateTime64('\0930-12-12 12:12:12.1234567', 3), toIntervalNanosecond(1024)). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/DateTimeTransforms.h:504: DB::ToStartOfInterval<(DB::IntervalKind::Kind)0>::execute(long, long, DateLUTImpl const&, long, long) @ 0x000000000e7a173f 5. /build/src/Functions/toStartOfInterval.cpp:423: COW::immutable_ptr DB::FunctionToStartOfInterval::execute, (DB::IntervalKind::Kind)0>(DB::DataTypeDateTime64 const&, DB::ColumnDecimal const&, long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e7ce4a1 6. /build/src/Functions/toStartOfInterval.cpp:329: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDateTime64 const&, DB::ColumnDecimal const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e7c55bc 7. /build/src/Functions/toStartOfInterval.cpp:286: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e79c9c3 8. /build/src/Functions/toStartOfInterval.cpp:249: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e79b630 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:12:19.878164 [ 16756 ] {d39b2275-4df5-45d2-b7a8-0d273b0ae9b4} executeQuery: Code: 407. DB::Exception: Numeric overflow: In scope SELECT toDateTime64(-9223372036854775808, 1048575, toIntervalNanosecond(9223372036854775806), NULL), toStartOfInterval(toDateTime64(toIntervalNanosecond(toIntervalNanosecond(257), toDateTime64(toStartOfInterval(toDateTime64(NULL)))), '', 100), toIntervalNanosecond(toStartOfInterval(toDateTime64(toIntervalNanosecond(NULL), NULL)), -1)), toStartOfInterval(toDateTime64('\0930-12-12 12:12:12.1234567', 3), toIntervalNanosecond(1024)). (DECIMAL_OVERFLOW) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42436) (comment: 02269_to_start_of_interval_overflow.sql) (query 2, line 3) (in query: SELECT toDateTime64(-9223372036854775808, 1048575, toIntervalNanosecond(9223372036854775806), NULL), toStartOfInterval(toDateTime64(toIntervalNanosecond(toIntervalNanosecond(257), toDateTime64(toStartOfInterval(toDateTime64(NULL)))), '', 100), toIntervalNanosecond(toStartOfInterval(toDateTime64(toIntervalNanosecond(NULL), NULL)), -1)), toStartOfInterval(toDateTime64('\0930-12-12 12:12:12.1234567', 3), toIntervalNanosecond(1024));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/DateTimeTransforms.h:504: DB::ToStartOfInterval<(DB::IntervalKind::Kind)0>::execute(long, long, DateLUTImpl const&, long, long) @ 0x000000000e7a173f 5. /build/src/Functions/toStartOfInterval.cpp:423: COW::immutable_ptr DB::FunctionToStartOfInterval::execute, (DB::IntervalKind::Kind)0>(DB::DataTypeDateTime64 const&, DB::ColumnDecimal const&, long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e7ce4a1 6. /build/src/Functions/toStartOfInterval.cpp:329: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDateTime64 const&, DB::ColumnDecimal const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e7c55bc 7. /build/src/Functions/toStartOfInterval.cpp:286: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e79c9c3 8. /build/src/Functions/toStartOfInterval.cpp:249: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e79b630 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:12:19.960551 [ 16756 ] {} TCPHandler: Code: 407. DB::Exception: Numeric overflow: In scope SELECT toDateTime64(-9223372036854775808, 1048575, toIntervalNanosecond(9223372036854775806), NULL), toStartOfInterval(toDateTime64(toIntervalNanosecond(toIntervalNanosecond(257), toDateTime64(toStartOfInterval(toDateTime64(NULL)))), '', 100), toIntervalNanosecond(toStartOfInterval(toDateTime64(toIntervalNanosecond(NULL), NULL)), -1)), toStartOfInterval(toDateTime64('\0930-12-12 12:12:12.1234567', 3), toIntervalNanosecond(1024)). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/DateTimeTransforms.h:504: DB::ToStartOfInterval<(DB::IntervalKind::Kind)0>::execute(long, long, DateLUTImpl const&, long, long) @ 0x000000000e7a173f 5. /build/src/Functions/toStartOfInterval.cpp:423: COW::immutable_ptr DB::FunctionToStartOfInterval::execute, (DB::IntervalKind::Kind)0>(DB::DataTypeDateTime64 const&, DB::ColumnDecimal const&, long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e7ce4a1 6. /build/src/Functions/toStartOfInterval.cpp:329: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDateTime64 const&, DB::ColumnDecimal const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e7c55bc 7. /build/src/Functions/toStartOfInterval.cpp:286: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e79c9c3 8. /build/src/Functions/toStartOfInterval.cpp:249: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e79b630 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:12:20.155087 [ 16758 ] {86688824-627d-4a07-baa2-75f8e44b2309} executeQuery: Code: 32. DB::Exception: Attempt to read after eof: Cannot parse Decimal(76, 4) from String, because value is too short: In scope SELECT toDecimal256('', 4). (ATTEMPT_TO_READ_AFTER_EOF) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46028) (comment: 00700_to_decimal_or_something_1.gen.sql) (query 32, line 35) (in query: SELECT toDecimal256 ('', 4);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/IO/VarInt.cpp:13: DB::throwReadAfterEOF() @ 0x000000000fb986db 5. /build/src/IO/readDecimalText.h:35: bool DB::readDigits>>(DB::ReadBuffer&, DB::Decimal>&, unsigned int&, int&, bool) @ 0x00000000138a175f 6. /build/src/IO/readDecimalText.h:154: void DB::readDecimalText>, void>(DB::ReadBuffer&, DB::Decimal>&, unsigned int, unsigned int&, bool) @ 0x0000000013b5b34e 7. /build/src/DataTypes/Serializations/SerializationDecimal.cpp:46: DB::SerializationDecimal>>::readText(DB::Decimal>&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x0000000013bb8fd4 8. /build/src/Functions/FunctionsConversion.h:1014: COW::immutable_ptr DB::detail::ConvertThroughParsing>>, DB::detail::NameToDecimal256, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000013046681 9. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::detail::NameToDecimal256, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000001304639e 10. /build/src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>>, DB::detail::NameToDecimal256, 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 @ 0x00000000130343a4 11. /build/src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>>, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal256, 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::NameToDecimal256, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e983a1 12. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal256, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ebc8ce 13. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal256, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ebc0fa 14. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 15. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 16. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 17. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 18. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 19. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 20. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 27. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 28. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 2025.07.13 02:12:20.235996 [ 16758 ] {} TCPHandler: Code: 32. DB::Exception: Attempt to read after eof: Cannot parse Decimal(76, 4) from String, because value is too short: In scope SELECT toDecimal256('', 4). (ATTEMPT_TO_READ_AFTER_EOF), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/IO/VarInt.cpp:13: DB::throwReadAfterEOF() @ 0x000000000fb986db 5. /build/src/IO/readDecimalText.h:35: bool DB::readDigits>>(DB::ReadBuffer&, DB::Decimal>&, unsigned int&, int&, bool) @ 0x00000000138a175f 6. /build/src/IO/readDecimalText.h:154: void DB::readDecimalText>, void>(DB::ReadBuffer&, DB::Decimal>&, unsigned int, unsigned int&, bool) @ 0x0000000013b5b34e 7. /build/src/DataTypes/Serializations/SerializationDecimal.cpp:46: DB::SerializationDecimal>>::readText(DB::Decimal>&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x0000000013bb8fd4 8. /build/src/Functions/FunctionsConversion.h:1014: COW::immutable_ptr DB::detail::ConvertThroughParsing>>, DB::detail::NameToDecimal256, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000013046681 9. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::detail::NameToDecimal256, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000001304639e 10. /build/src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>>, DB::detail::NameToDecimal256, 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 @ 0x00000000130343a4 11. /build/src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>>, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal256, 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::NameToDecimal256, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e983a1 12. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal256, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ebc8ce 13. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal256, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ebc0fa 14. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 15. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 16. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 17. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 18. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 19. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 20. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 27. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 28. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 2025.07.13 02:12:20.335042 [ 16758 ] {a1258a9f-c8c6-45d3-aa58-ae660d8d74d6} executeQuery: Code: 6. DB::Exception: Cannot parse string '\0' as Decimal(76, 4): syntax error at begin of string: In scope SELECT toDecimal256('\0', 4). (CANNOT_PARSE_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46028) (comment: 00700_to_decimal_or_something_1.gen.sql) (query 33, line 36) (in query: SELECT toDecimal256 ('\0', 4);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing>>, DB::detail::NameToDecimal256, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000013046757 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::detail::NameToDecimal256, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000001304639e 6. /build/src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>>, DB::detail::NameToDecimal256, 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 @ 0x00000000130343a4 7. /build/src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>>, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal256, 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::NameToDecimal256, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e983a1 8. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal256, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ebc8ce 9. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal256, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ebc0fa 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 31. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 2025.07.13 02:12:20.351515 [ 16758 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '\0' as Decimal(76, 4): syntax error at begin of string: In scope SELECT toDecimal256('\0', 4). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing>>, DB::detail::NameToDecimal256, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000013046757 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::detail::NameToDecimal256, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000001304639e 6. /build/src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>>, DB::detail::NameToDecimal256, 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 @ 0x00000000130343a4 7. /build/src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>>, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal256, 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::NameToDecimal256, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e983a1 8. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal256, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ebc8ce 9. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal256, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ebc0fa 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 31. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 2025.07.13 02:12:20.542753 [ 16758 ] {9bc90198-ee34-4912-937b-9db3ac2f808d} executeQuery: Code: 6. DB::Exception: Cannot parse string '\0\0\0\0\0' as Decimal(76, 4): syntax error at begin of string: In scope SELECT toDecimal256('\0\0\0\0\0', 4). (CANNOT_PARSE_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46028) (comment: 00700_to_decimal_or_something_1.gen.sql) (query 34, line 37) (in query: SELECT toDecimal256 ('\0\0\0\0\0', 4);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing>>, DB::detail::NameToDecimal256, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000013046757 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::detail::NameToDecimal256, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000001304639e 6. /build/src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>>, DB::detail::NameToDecimal256, 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 @ 0x00000000130343a4 7. /build/src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>>, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal256, 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::NameToDecimal256, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e983a1 8. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal256, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ebc8ce 9. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal256, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ebc0fa 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 31. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 2025.07.13 02:12:20.550076 [ 16758 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '\0\0\0\0\0' as Decimal(76, 4): syntax error at begin of string: In scope SELECT toDecimal256('\0\0\0\0\0', 4). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing>>, DB::detail::NameToDecimal256, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000013046757 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::detail::NameToDecimal256, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000001304639e 6. /build/src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>>, DB::detail::NameToDecimal256, 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 @ 0x00000000130343a4 7. /build/src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>>, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal256, 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::NameToDecimal256, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e983a1 8. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal256, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ebc8ce 9. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal256, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ebc0fa 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 31. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 2025.07.13 02:12:20.670115 [ 16758 ] {a76848ef-d01e-40c1-9576-2e292efee4c7} executeQuery: Code: 6. DB::Exception: Cannot parse string '\n\t\r' as Decimal(76, 4): syntax error at begin of string: In scope SELECT toDecimal256('\n\t\r', 4). (CANNOT_PARSE_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46028) (comment: 00700_to_decimal_or_something_1.gen.sql) (query 35, line 38) (in query: SELECT toDecimal256 ('\n\t\r', 4);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing>>, DB::detail::NameToDecimal256, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000013046757 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::detail::NameToDecimal256, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000001304639e 6. /build/src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>>, DB::detail::NameToDecimal256, 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 @ 0x00000000130343a4 7. /build/src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>>, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal256, 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::NameToDecimal256, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e983a1 8. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal256, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ebc8ce 9. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal256, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ebc0fa 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 31. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 2025.07.13 02:12:20.703901 [ 16758 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '\n\t\r' as Decimal(76, 4): syntax error at begin of string: In scope SELECT toDecimal256('\n\t\r', 4). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing>>, DB::detail::NameToDecimal256, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000013046757 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::detail::NameToDecimal256, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000001304639e 6. /build/src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>>, DB::detail::NameToDecimal256, 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 @ 0x00000000130343a4 7. /build/src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>>, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal256, 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::NameToDecimal256, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e983a1 8. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal256, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ebc8ce 9. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal256, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ebc0fa 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 31. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 2025.07.13 02:12:20.866332 [ 16758 ] {4c984e8a-408b-4fd7-9a4d-f1c9a889ad9b} executeQuery: Code: 6. DB::Exception: Cannot parse string '\'' as Decimal(76, 4): syntax error at begin of string: In scope SELECT toDecimal256('\'', 4). (CANNOT_PARSE_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46028) (comment: 00700_to_decimal_or_something_1.gen.sql) (query 36, line 39) (in query: SELECT toDecimal256 ('\'', 4);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing>>, DB::detail::NameToDecimal256, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000013046757 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::detail::NameToDecimal256, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000001304639e 6. /build/src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>>, DB::detail::NameToDecimal256, 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 @ 0x00000000130343a4 7. /build/src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>>, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal256, 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::NameToDecimal256, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e983a1 8. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal256, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ebc8ce 9. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal256, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ebc0fa 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 31. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 2025.07.13 02:12:20.884062 [ 16758 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '\'' as Decimal(76, 4): syntax error at begin of string: In scope SELECT toDecimal256('\'', 4). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing>>, DB::detail::NameToDecimal256, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000013046757 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::detail::NameToDecimal256, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000001304639e 6. /build/src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>>, DB::detail::NameToDecimal256, 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 @ 0x00000000130343a4 7. /build/src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>>, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal256, 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::NameToDecimal256, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e983a1 8. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal256, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ebc8ce 9. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal256, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012ebc0fa 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 31. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 2025.07.13 02:12:21.271408 [ 6612 ] {93150240-8619-44eb-b0ce-d6ceac0c9110} executeQuery: Code: 407. DB::Exception: Numeric overflow: While executing ConvertingAggregatedToChunksTransform. (DECIMAL_OVERFLOW) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42458) (comment: 02029_quantile_sanitizer.sql) (query 1, line 1) (in query: SELECT quantileTDigestWeighted(-0.)(toDateTime(10000000000.), 1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/AggregateFunctions/QuantileTDigest.h:531: unsigned int DB::QuantileTDigest::checkOverflow(float) @ 0x00000000106ca632 5. /build/src/AggregateFunctions/QuantileTDigest.h:506: DB::AggregateFunctionQuantile, DB::NameQuantileTDigestWeighted, true, void, false, false>::insertResultInto(char*, DB::IColumn&, DB::Arena*) const @ 0x00000000107053d6 6. /build/src/Interpreters/Aggregator.cpp:1908: void DB::Aggregator::insertAggregatesIntoColumns(char*&, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::Arena*) const @ 0x0000000014539b80 7. /build/src/Interpreters/Aggregator.cpp:2265: DB::Aggregator::prepareBlockAndFillWithoutKey(DB::AggregatedDataVariants&, bool, bool) const @ 0x00000000144bcc79 8. /build/src/Processors/Transforms/AggregatingTransform.cpp:467: DB::ConvertingAggregatedToChunksTransform::initialize() @ 0x0000000016b1bbe0 9. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 10. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 11. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 12. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 14. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:12:21.282397 [ 6612 ] {} TCPHandler: Code: 407. DB::Exception: Numeric overflow: While executing ConvertingAggregatedToChunksTransform. (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/AggregateFunctions/QuantileTDigest.h:531: unsigned int DB::QuantileTDigest::checkOverflow(float) @ 0x00000000106ca632 5. /build/src/AggregateFunctions/QuantileTDigest.h:506: DB::AggregateFunctionQuantile, DB::NameQuantileTDigestWeighted, true, void, false, false>::insertResultInto(char*, DB::IColumn&, DB::Arena*) const @ 0x00000000107053d6 6. /build/src/Interpreters/Aggregator.cpp:1908: void DB::Aggregator::insertAggregatesIntoColumns(char*&, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::Arena*) const @ 0x0000000014539b80 7. /build/src/Interpreters/Aggregator.cpp:2265: DB::Aggregator::prepareBlockAndFillWithoutKey(DB::AggregatedDataVariants&, bool, bool) const @ 0x00000000144bcc79 8. /build/src/Processors/Transforms/AggregatingTransform.cpp:467: DB::ConvertingAggregatedToChunksTransform::initialize() @ 0x0000000016b1bbe0 9. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 10. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 11. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 12. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 14. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:12:23.282029 [ 11499 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:12:27.896624 [ 5998 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000013779f8b 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000137794b8 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778bc3 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678d325 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:12:28.057624 [ 11499 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:12:29.338362 [ 6619 ] {c2415d0c-3fcd-4f38-847c-769708227af3} executeQuery: Code: 57. DB::Exception: Table test_074lsno0.array_element_or_null_test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 03240_array_element_or_null.sql) (in query: /* ddl_entry=query-0000000004 */ CREATE TABLE test_074lsno0.array_element_or_null_test UUID 'ab58fa03-4f73-4595-8db8-f738ca2460b8' (`arr` Array(Int32), `id` UInt32) ENGINE = Memory), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 12. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:12:29.384263 [ 6619 ] {c2415d0c-3fcd-4f38-847c-769708227af3} executeQuery: Code: 57. DB::Exception: Table test_074lsno0.array_element_or_null_test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42538) (comment: 03240_array_element_or_null.sql) (query 6, line 8) (in query: CREATE TABLE array_element_or_null_test (arr Array(Int32), id UInt32) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 12. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:12:29.406835 [ 6619 ] {} TCPHandler: Code: 57. DB::Exception: Table test_074lsno0.array_element_or_null_test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 12. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:12:29.417294 [ 4888 ] {51066849-99e0-4fd4-ab7a-35fdbed7a35b} executeQuery: Code: 159. DB::Exception: Timeout exceeded (180 s) while flushing system log 'DB::SystemLogQueue'. (TIMEOUT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38402) (comment: 01526_max_untracked_memory.sh) (query 1, line 1) (in query: SYSTEM FLUSH LOGS query_log, trace_log), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Common/SystemLogBase.cpp:168: DB::SystemLogQueue::waitFlush(long, bool) @ 0x000000000fbee407 5. /build/src/Interpreters/SystemLog.cpp:437: DB::SystemLogs::flush(bool, std::vector> const&) @ 0x0000000014a1ea9f 6. /build/src/Interpreters/InterpreterSystemQuery.cpp:796: DB::InterpreterSystemQuery::execute() @ 0x0000000014bd5a4e 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:12:29.430348 [ 4888 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded (180 s) while flushing system log 'DB::SystemLogQueue'. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Common/SystemLogBase.cpp:168: DB::SystemLogQueue::waitFlush(long, bool) @ 0x000000000fbee407 5. /build/src/Interpreters/SystemLog.cpp:437: DB::SystemLogs::flush(bool, std::vector> const&) @ 0x0000000014a1ea9f 6. /build/src/Interpreters/InterpreterSystemQuery.cpp:796: DB::InterpreterSystemQuery::execute() @ 0x0000000014bd5a4e 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:12:30.443851 [ 5117 ] {82420803-0a63-475f-96a0-f5e4e416b17d} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 REMOVE MATERIALIZED'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 11, line 79) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 REMOVE MATERIALIZED');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:763: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795ef7d 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:30.471974 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 REMOVE MATERIALIZED'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:763: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795ef7d 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:30.637966 [ 5117 ] {2a9342ea-e10b-448f-9cd5-45a3a7ece450} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y DEFAULT 2 REMOVE MATERIALIZED'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 12, line 80) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y DEFAULT 2 REMOVE MATERIALIZED');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:763: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795ef7d 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:30.654281 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y DEFAULT 2 REMOVE MATERIALIZED'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:763: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795ef7d 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:30.685043 [ 5998 ] {459fc925-a40b-455d-acb0-b356e52209d1} executeQuery: Code: 524. DB::Exception: Trying to ALTER DROP key key1 column which is a part of key expression. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52164) (comment: 01416_clear_column_pk.sql) (query 4, line 14) (in query: ALTER TABLE table_with_pk_clear CLEAR COLUMN key1 IN PARTITION tuple();), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3748: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001625bd2e 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd033 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:12:30.693078 [ 5998 ] {} TCPHandler: Code: 524. DB::Exception: Trying to ALTER DROP key key1 column which is a part of key expression. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3748: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001625bd2e 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd033 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:12:30.792232 [ 5117 ] {102fe585-f7e0-459e-ae98-4724abc179d8} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y MATERIALIZED 3 REMOVE MATERIALIZED'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 13, line 81) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y MATERIALIZED 3 REMOVE MATERIALIZED');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:763: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795ef7d 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:30.822451 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y MATERIALIZED 3 REMOVE MATERIALIZED'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:763: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795ef7d 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:30.986206 [ 5117 ] {a298e64c-bca2-45bb-b22c-be1561f24e67} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y EPHEMERAL 4 REMOVE MATERIALIZED'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 14, line 82) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y EPHEMERAL 4 REMOVE MATERIALIZED');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:763: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795ef7d 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:30.994223 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y EPHEMERAL 4 REMOVE MATERIALIZED'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:763: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795ef7d 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:31.077943 [ 5117 ] {d6e90e22-63cd-488d-8ddd-62c9ba2ad2cd} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y COMMENT \'5\' REMOVE MATERIALIZED'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 15, line 83) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y COMMENT \'5\' REMOVE MATERIALIZED');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:763: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795ef7d 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:31.084742 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y COMMENT \'5\' REMOVE MATERIALIZED'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:763: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795ef7d 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:31.318989 [ 5117 ] {0dcf4dfd-8ab8-46ff-98d5-a37c68954659} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y CODEC(ZSTD) REMOVE MATERIALIZED'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 16, line 84) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y CODEC(ZSTD) REMOVE MATERIALIZED');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:763: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795ef7d 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:31.320415 [ 5998 ] {dfc4aaa0-de1e-4cd0-86eb-e74fcc491485} executeQuery: Code: 524. DB::Exception: Trying to ALTER DROP key key2 column which is a part of key expression. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52164) (comment: 01416_clear_column_pk.sql) (query 6, line 18) (in query: ALTER TABLE table_with_pk_clear CLEAR COLUMN key2 IN PARTITION tuple();), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3748: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001625bd2e 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd033 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:12:31.352652 [ 5998 ] {} TCPHandler: Code: 524. DB::Exception: Trying to ALTER DROP key key2 column which is a part of key expression. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3748: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001625bd2e 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd033 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:12:31.352843 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y CODEC(ZSTD) REMOVE MATERIALIZED'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:763: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795ef7d 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:31.537136 [ 5117 ] {cfa89569-7bdd-484b-88ab-1d75ff1e0018} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y STATISTICS(tdigest) REMOVE MATERIALIZED'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 17, line 85) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y STATISTICS(tdigest) REMOVE MATERIALIZED');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:763: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795ef7d 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:31.552665 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y STATISTICS(tdigest) REMOVE MATERIALIZED'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:763: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795ef7d 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:31.732200 [ 5117 ] {f8a1903e-fd7f-4e4b-b141-722d7f26ae4c} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 35 (toDate): toDate('2025-01-01') + toIntervalDay(x) REMOVE MATERIALIZED. Expected one of: COLLATE, DEFAULT, MATERIALIZED, ALIAS, EPHEMERAL, AUTO_INCREMENT, COMMENT, CODEC, STATISTICS, TTL, PRIMARY KEY, SETTINGS, REMOVE, MODIFY SETTING, RESET SETTING, FIRST, AFTER, token, Comma, INTO OUTFILE, FORMAT, ParallelWithClause, PARALLEL WITH, end of query: In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y TTL toDate(\'2025-01-01\') + toIntervalDay(x) REMOVE MATERIALIZED'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 18, line 86) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y TTL toDate(\'2025-01-01\') + toIntervalDay(x) REMOVE MATERIALIZED');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000009fd29ed 3. /build/src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9acc 4. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 5. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:12:31.786728 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Syntax error: failed at position 35 (toDate): toDate('2025-01-01') + toIntervalDay(x) REMOVE MATERIALIZED. Expected one of: COLLATE, DEFAULT, MATERIALIZED, ALIAS, EPHEMERAL, AUTO_INCREMENT, COMMENT, CODEC, STATISTICS, TTL, PRIMARY KEY, SETTINGS, REMOVE, MODIFY SETTING, RESET SETTING, FIRST, AFTER, token, Comma, INTO OUTFILE, FORMAT, ParallelWithClause, PARALLEL WITH, end of query: In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y TTL toDate(\'2025-01-01\') + toIntervalDay(x) REMOVE MATERIALIZED'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000009fd29ed 3. /build/src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9acc 4. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 5. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:12:31.995456 [ 5117 ] {6343eeed-400d-4455-8a23-27fccfbefd25} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 39 (binary): binary REMOVE MATERIALIZED. Expected one of: COLLATE, DEFAULT, MATERIALIZED, ALIAS, EPHEMERAL, AUTO_INCREMENT, COMMENT, CODEC, STATISTICS, TTL, PRIMARY KEY, SETTINGS, REMOVE, MODIFY SETTING, RESET SETTING, FIRST, AFTER, token, Comma, INTO OUTFILE, FORMAT, ParallelWithClause, PARALLEL WITH, end of query: In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y COLLATE binary REMOVE MATERIALIZED'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 19, line 87) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y COLLATE binary REMOVE MATERIALIZED');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000009fd29ed 3. /build/src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9acc 4. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 5. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:12:32.008106 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Syntax error: failed at position 39 (binary): binary REMOVE MATERIALIZED. Expected one of: COLLATE, DEFAULT, MATERIALIZED, ALIAS, EPHEMERAL, AUTO_INCREMENT, COMMENT, CODEC, STATISTICS, TTL, PRIMARY KEY, SETTINGS, REMOVE, MODIFY SETTING, RESET SETTING, FIRST, AFTER, token, Comma, INTO OUTFILE, FORMAT, ParallelWithClause, PARALLEL WITH, end of query: In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y COLLATE binary REMOVE MATERIALIZED'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000009fd29ed 3. /build/src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9acc 4. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 5. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:12:32.127208 [ 4870 ] {7edab75c-c69c-4521-bf0a-b2a8d810a764} executeQuery: Code: 57. DB::Exception: Table test_9.test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52958) (comment: 03037_dynamic_merges_small.gen.sql) (query 43, line 52) (in query: CREATE TABLE test (`id` UInt64, `d` Dynamic(max_types = 2)) ENGINE = MergeTree ORDER BY id SETTINGS min_rows_for_wide_part = 1000000000, min_bytes_for_wide_part = 10000000000, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, index_granularity = 4456, 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 = 257331891, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 10174361, merge_max_block_size = 6383, old_parts_lifetime = 193., prefer_fetch_merged_part_size_threshold = 10737418240, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 14608803, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 2, 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 = 72449, primary_key_compress_block_size = 32334, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:12:32.199755 [ 4870 ] {} TCPHandler: Code: 57. DB::Exception: Table test_9.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:12:32.213424 [ 5117 ] {fb9fe774-830f-435a-9677-86a673e77964} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 65 (=): = 20000) REMOVE MATERIALIZED. Expected one of: list, delimited by binary operators, literal, NULL, NULL, number, Bool, TRUE, FALSE, string literal, combination of maps, arrays, tuples, data type, identifier: In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y SETTINGS (max_compress_block_size = 20000) REMOVE MATERIALIZED'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 20, line 88) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y SETTINGS (max_compress_block_size = 20000) REMOVE MATERIALIZED');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000009fd29ed 3. /build/src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9acc 4. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 5. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:12:32.240043 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Syntax error: failed at position 65 (=): = 20000) REMOVE MATERIALIZED. Expected one of: list, delimited by binary operators, literal, NULL, NULL, number, Bool, TRUE, FALSE, string literal, combination of maps, arrays, tuples, data type, identifier: In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y SETTINGS (max_compress_block_size = 20000) REMOVE MATERIALIZED'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000009fd29ed 3. /build/src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9acc 4. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 5. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:12:32.462380 [ 5117 ] {699f5c94-0a34-4ffa-b1db-1b50d70521ed} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y PRIMARY KEY REMOVE MATERIALIZED'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 21, line 89) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y PRIMARY KEY REMOVE MATERIALIZED');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:763: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795ef7d 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:32.501562 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y PRIMARY KEY REMOVE MATERIALIZED'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:763: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795ef7d 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:32.811477 [ 5117 ] {e4dadd55-c7f6-43bd-b68e-afb66c1e7c70} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 DEFAULT 2 REMOVE MATERIALIZED'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 23, line 92) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 DEFAULT 2 REMOVE MATERIALIZED');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:763: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795ef7d 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:32.879464 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 DEFAULT 2 REMOVE MATERIALIZED'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:763: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795ef7d 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:33.015949 [ 5117 ] {e4fb6967-5199-4b3d-8b34-1a4c1c206244} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 MATERIALIZED 3 REMOVE MATERIALIZED'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 24, line 93) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 MATERIALIZED 3 REMOVE MATERIALIZED');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:763: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795ef7d 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:33.093608 [ 11499 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:12:33.107764 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 MATERIALIZED 3 REMOVE MATERIALIZED'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:763: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795ef7d 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:33.220402 [ 5117 ] {b80a7700-21f9-40ef-9ceb-ef1daf510f3a} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 EPHEMERAL 4 REMOVE MATERIALIZED'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 25, line 94) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 EPHEMERAL 4 REMOVE MATERIALIZED');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:763: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795ef7d 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:33.238941 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 EPHEMERAL 4 REMOVE MATERIALIZED'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:763: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795ef7d 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:33.477910 [ 5117 ] {35336090-61c7-407a-aadb-8dfa4ef6fb2e} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 COMMENT \'5\' REMOVE MATERIALIZED'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 26, line 95) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 COMMENT \'5\' REMOVE MATERIALIZED');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:763: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795ef7d 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:33.510900 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 COMMENT \'5\' REMOVE MATERIALIZED'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:763: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795ef7d 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:33.710689 [ 5117 ] {7d9b9017-8c61-4c14-bc8b-9bb4ca9501da} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 CODEC(ZSTD) REMOVE MATERIALIZED'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 27, line 96) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 CODEC(ZSTD) REMOVE MATERIALIZED');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:763: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795ef7d 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:33.754991 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 CODEC(ZSTD) REMOVE MATERIALIZED'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:763: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795ef7d 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:33.852311 [ 5117 ] {d8acaf91-b7f4-4c3d-9320-747ed0f18237} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 STATISTICS(tdigest) REMOVE MATERIALIZED'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 28, line 97) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 STATISTICS(tdigest) REMOVE MATERIALIZED');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:763: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795ef7d 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:33.861477 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 STATISTICS(tdigest) REMOVE MATERIALIZED'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:763: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795ef7d 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:34.055295 [ 5117 ] {96d5d88a-5b01-40f3-943c-1c8b6bc5b6af} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 TTL toDate(\'2025-01-01\') + toIntervalDay(x) REMOVE MATERIALIZED'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 29, line 98) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 TTL toDate(\'2025-01-01\') + toIntervalDay(x) REMOVE MATERIALIZED');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:763: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795ef7d 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:34.099141 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 TTL toDate(\'2025-01-01\') + toIntervalDay(x) REMOVE MATERIALIZED'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:763: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795ef7d 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:34.353732 [ 5117 ] {5f93a1c0-7de2-4074-aded-f39aede8d809} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 COLLATE binary REMOVE MATERIALIZED'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 30, line 99) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 COLLATE binary REMOVE MATERIALIZED');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:763: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795ef7d 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:34.422648 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 COLLATE binary REMOVE MATERIALIZED'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:763: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795ef7d 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:34.556114 [ 5117 ] {c1b2c8dc-31ca-41cb-a30e-0ad8c6fd52b7} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 SETTINGS (max_compress_block_size = 20000) REMOVE MATERIALIZED'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 31, line 100) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 SETTINGS (max_compress_block_size = 20000) REMOVE MATERIALIZED');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:763: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795ef7d 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:34.687922 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 SETTINGS (max_compress_block_size = 20000) REMOVE MATERIALIZED'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:763: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795ef7d 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:34.827045 [ 5117 ] {ed380878-2d2a-453a-834e-678ee0fbf5bc} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 PRIMARY KEY REMOVE MATERIALIZED'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 32, line 101) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 PRIMARY KEY REMOVE MATERIALIZED');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:763: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795ef7d 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:34.853256 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'REMOVE': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 PRIMARY KEY REMOVE MATERIALIZED'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:763: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795ef7d 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:35.512234 [ 5117 ] {3a729fb3-cb2b-4860-96dd-8d2a35c60ce3} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 34, line 104) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 MODIFY SETTING max_compress_block_size = 20000');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:784: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f06c 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:35.519200 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:784: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f06c 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:35.577545 [ 6166 ] {ad7ba6bd-bad8-4b89-9d28-9fc2e09a990b} executeQuery: Code: 643. DB::Exception: Couldn't open archive '/var/lib/clickhouse/user_files/02994_file_1752365543/test.rar.7z': Unrecognized archive format: The table structure cannot be extracted from a CSV format file. You can specify the structure manually. (CANNOT_UNPACK_ARCHIVE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52356) (comment: 02994_libarchive_compression.sh) (query 1, line 1) (in query: SELECT c1 FROM file('02994_file_1752365543/test.rar.7z :: test.csv', CSV);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, char const*&&) @ 0x000000001174aacb 4. /build/src/IO/Archives/LibArchiveReader.cpp:240: DB::LibArchiveReader::Handle::openWithPath(String const&) @ 0x000000001324d74f 5. /build/src/IO/Archives/LibArchiveReader.cpp:43: DB::LibArchiveReader::Handle::Handle(String, bool) @ 0x000000001324c6ba 6. /build/src/IO/Archives/LibArchiveReader.cpp:485: DB::LibArchiveReader::acquireHandle() @ 0x000000001324a648 7. /build/src/IO/Archives/LibArchiveReader.cpp:405: DB::LibArchiveReader::readFile(String const&, bool) @ 0x000000001324ab07 8. /build/src/Storages/StorageFile.cpp:702: DB::(anonymous namespace)::ReadBufferFromArchiveIterator::next() @ 0x0000000015cb48f5 9. /build/src/Formats/ReadSchemaUtils.cpp:152: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x0000000016896ec7 10. /build/src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001689af42 11. /build/src/Storages/StorageFile.cpp:978: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x0000000015ca6741 12. /build/src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x0000000015ca6f9c 13. /build/src/Storages/StorageFile.cpp:1122: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x0000000015ca7e12 14. /build/src/Storages/StorageFile.cpp:1063: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x0000000015ca95f9 15. /build/src/Storages/StorageFile.cpp:1067: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x0000000015ca9c5c 16. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], String const&, String, bool, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x00000000117228aa 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x0000000011720b78 18. /build/src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000011723a7c 19. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000130d4903 20. /build/src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000143537f2 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3da49 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 25. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 26. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 31. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 2025.07.13 02:12:35.600199 [ 6166 ] {} TCPHandler: Code: 643. DB::Exception: Couldn't open archive '/var/lib/clickhouse/user_files/02994_file_1752365543/test.rar.7z': Unrecognized archive format: The table structure cannot be extracted from a CSV format file. You can specify the structure manually. (CANNOT_UNPACK_ARCHIVE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, char const*&&) @ 0x000000001174aacb 4. /build/src/IO/Archives/LibArchiveReader.cpp:240: DB::LibArchiveReader::Handle::openWithPath(String const&) @ 0x000000001324d74f 5. /build/src/IO/Archives/LibArchiveReader.cpp:43: DB::LibArchiveReader::Handle::Handle(String, bool) @ 0x000000001324c6ba 6. /build/src/IO/Archives/LibArchiveReader.cpp:485: DB::LibArchiveReader::acquireHandle() @ 0x000000001324a648 7. /build/src/IO/Archives/LibArchiveReader.cpp:405: DB::LibArchiveReader::readFile(String const&, bool) @ 0x000000001324ab07 8. /build/src/Storages/StorageFile.cpp:702: DB::(anonymous namespace)::ReadBufferFromArchiveIterator::next() @ 0x0000000015cb48f5 9. /build/src/Formats/ReadSchemaUtils.cpp:152: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x0000000016896ec7 10. /build/src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001689af42 11. /build/src/Storages/StorageFile.cpp:978: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x0000000015ca6741 12. /build/src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x0000000015ca6f9c 13. /build/src/Storages/StorageFile.cpp:1122: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x0000000015ca7e12 14. /build/src/Storages/StorageFile.cpp:1063: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x0000000015ca95f9 15. /build/src/Storages/StorageFile.cpp:1067: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x0000000015ca9c5c 16. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], String const&, String, bool, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x00000000117228aa 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x0000000011720b78 18. /build/src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000011723a7c 19. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000130d4903 20. /build/src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000143537f2 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3da49 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 25. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 26. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 31. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 2025.07.13 02:12:35.691544 [ 5117 ] {972ae3bc-f3e2-47d1-9802-1629aa0dc2c3} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y DEFAULT 2 MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 35, line 105) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y DEFAULT 2 MODIFY SETTING max_compress_block_size = 20000');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:784: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f06c 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:35.706425 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y DEFAULT 2 MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:784: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f06c 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:35.856621 [ 5117 ] {52537602-4efc-4ca7-be2d-960b8da4cd8f} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y MATERIALIZED 3 MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 36, line 106) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y MATERIALIZED 3 MODIFY SETTING max_compress_block_size = 20000');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:784: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f06c 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:35.889220 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y MATERIALIZED 3 MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:784: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f06c 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:36.068618 [ 5117 ] {2d5fe92b-8d04-4646-88cd-43849ee1a521} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y EPHEMERAL 4 MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 37, line 107) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y EPHEMERAL 4 MODIFY SETTING max_compress_block_size = 20000');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:784: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f06c 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:36.076353 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y EPHEMERAL 4 MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:784: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f06c 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:36.200764 [ 5117 ] {25ec12f5-46d0-4345-8163-7593c1717b79} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y COMMENT \'5\' MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 38, line 108) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y COMMENT \'5\' MODIFY SETTING max_compress_block_size = 20000');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:784: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f06c 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:36.229684 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y COMMENT \'5\' MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:784: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f06c 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:36.414476 [ 5117 ] {a4b81eb0-e244-4520-9595-eb16da3852e1} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y CODEC(ZSTD) MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 39, line 109) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y CODEC(ZSTD) MODIFY SETTING max_compress_block_size = 20000');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:784: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f06c 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:36.435114 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y CODEC(ZSTD) MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:784: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f06c 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:36.510728 [ 6166 ] {} TCPHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000013779f8b 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000137794b8 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778c58 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168167bf 10. /build/src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000001680ff45 11. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:12:36.515578 [ 6166 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x0000000016810069 5. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 6. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 2025.07.13 02:12:36.535051 [ 27539 ] {f1e60821-3627-4827-b250-5c0c1cbfba7d} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000013779f8b 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000137794b8 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778c58 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168167bf 10. /build/src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000001680ff45 11. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52298) (comment: 03156_analyzer_array_join_distributed.sql) (query 3, line 5) (in query: SELECT s, arr, a FROM remote('127.0.0.2', currentDatabase(), arrays_test) ARRAY JOIN arr AS a WHERE a < 3 ORDER BY a;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fb80677 3. /build/src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x00000000166f5247 4. /build/src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000166fc432 5. /build/src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001673a5f3 6. /build/src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013af6952 7. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013af679a 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013af64e1 2025.07.13 02:12:36.587033 [ 27539 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000013779f8b 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000137794b8 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778c58 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168167bf 10. /build/src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000001680ff45 11. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fb80677 3. /build/src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x00000000166f5247 4. /build/src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000166fc432 5. /build/src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001673a5f3 6. /build/src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013af6952 7. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013af679a 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013af64e1 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:12:36.601309 [ 5117 ] {3db9d0e4-52b3-4203-8098-dfb46c837216} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y STATISTICS(tdigest) MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 40, line 110) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y STATISTICS(tdigest) MODIFY SETTING max_compress_block_size = 20000');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:784: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f06c 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:36.612761 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y STATISTICS(tdigest) MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:784: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f06c 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:36.730051 [ 5117 ] {dd98970c-0f01-4213-bfa2-83e8b3a26047} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 35 (toDate): toDate('2025-01-01') + toIntervalDay(x) MODIFY SETTING max_compress_block_size = 20000. Expected one of: COLLATE, DEFAULT, MATERIALIZED, ALIAS, EPHEMERAL, AUTO_INCREMENT, COMMENT, CODEC, STATISTICS, TTL, PRIMARY KEY, SETTINGS, REMOVE, MODIFY SETTING, RESET SETTING, FIRST, AFTER, token, Comma, INTO OUTFILE, FORMAT, ParallelWithClause, PARALLEL WITH, end of query: In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y TTL toDate(\'2025-01-01\') + toIntervalDay(x) MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 41, line 111) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y TTL toDate(\'2025-01-01\') + toIntervalDay(x) MODIFY SETTING max_compress_block_size = 20000');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000009fd29ed 3. /build/src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9acc 4. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 5. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:12:36.754098 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Syntax error: failed at position 35 (toDate): toDate('2025-01-01') + toIntervalDay(x) MODIFY SETTING max_compress_block_size = 20000. Expected one of: COLLATE, DEFAULT, MATERIALIZED, ALIAS, EPHEMERAL, AUTO_INCREMENT, COMMENT, CODEC, STATISTICS, TTL, PRIMARY KEY, SETTINGS, REMOVE, MODIFY SETTING, RESET SETTING, FIRST, AFTER, token, Comma, INTO OUTFILE, FORMAT, ParallelWithClause, PARALLEL WITH, end of query: In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y TTL toDate(\'2025-01-01\') + toIntervalDay(x) MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000009fd29ed 3. /build/src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9acc 4. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 5. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:12:36.975000 [ 5117 ] {0ec81874-2234-4f3f-91a0-809fb6b02423} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 39 (binary): binary MODIFY SETTING max_compress_block_size = 20000. Expected one of: COLLATE, DEFAULT, MATERIALIZED, ALIAS, EPHEMERAL, AUTO_INCREMENT, COMMENT, CODEC, STATISTICS, TTL, PRIMARY KEY, SETTINGS, REMOVE, MODIFY SETTING, RESET SETTING, FIRST, AFTER, token, Comma, INTO OUTFILE, FORMAT, ParallelWithClause, PARALLEL WITH, end of query: In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y COLLATE binary MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 42, line 112) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y COLLATE binary MODIFY SETTING max_compress_block_size = 20000');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000009fd29ed 3. /build/src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9acc 4. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 5. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:12:37.001650 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Syntax error: failed at position 39 (binary): binary MODIFY SETTING max_compress_block_size = 20000. Expected one of: COLLATE, DEFAULT, MATERIALIZED, ALIAS, EPHEMERAL, AUTO_INCREMENT, COMMENT, CODEC, STATISTICS, TTL, PRIMARY KEY, SETTINGS, REMOVE, MODIFY SETTING, RESET SETTING, FIRST, AFTER, token, Comma, INTO OUTFILE, FORMAT, ParallelWithClause, PARALLEL WITH, end of query: In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y COLLATE binary MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000009fd29ed 3. /build/src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9acc 4. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 5. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:12:37.123729 [ 5117 ] {d79b31e0-e02c-44c6-8b4a-1d72d29578cc} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 54 (=): = 2) MODIFY SETTING max_compress_block_size = 20000. Expected one of: list, delimited by binary operators, literal, NULL, NULL, number, Bool, TRUE, FALSE, string literal, combination of maps, arrays, tuples, data type, identifier: In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y SETTINGS (some_setting = 2) MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 43, line 113) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y SETTINGS (some_setting = 2) MODIFY SETTING max_compress_block_size = 20000');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000009fd29ed 3. /build/src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9acc 4. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 5. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:12:37.133840 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Syntax error: failed at position 54 (=): = 2) MODIFY SETTING max_compress_block_size = 20000. Expected one of: list, delimited by binary operators, literal, NULL, NULL, number, Bool, TRUE, FALSE, string literal, combination of maps, arrays, tuples, data type, identifier: In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y SETTINGS (some_setting = 2) MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000009fd29ed 3. /build/src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9acc 4. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 5. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:12:37.239481 [ 5117 ] {7b509d6e-9573-4d0f-93ce-3c09b9f771c6} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y PRIMARY KEY MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 44, line 114) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y PRIMARY KEY MODIFY SETTING max_compress_block_size = 20000');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:784: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f06c 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:37.249257 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y PRIMARY KEY MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:784: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f06c 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:37.505389 [ 5117 ] {7c1764d4-46ad-4de6-9deb-ca43ff5454d2} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 DEFAULT 2 MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 46, line 117) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 DEFAULT 2 MODIFY SETTING max_compress_block_size = 20000');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:784: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f06c 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:37.509384 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 DEFAULT 2 MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:784: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f06c 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:37.594468 [ 5117 ] {e6e45072-ccfd-42e0-b4a5-971cbb12c1f6} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 MATERIALIZED 3 MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 47, line 118) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 MATERIALIZED 3 MODIFY SETTING max_compress_block_size = 20000');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:784: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f06c 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:37.615680 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 MATERIALIZED 3 MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:784: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f06c 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:37.814044 [ 5117 ] {363235e0-5ca4-47b0-96a5-72986516cb89} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 EPHEMERAL 4 MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 48, line 119) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 EPHEMERAL 4 MODIFY SETTING max_compress_block_size = 20000');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:784: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f06c 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:37.832071 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 EPHEMERAL 4 MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:784: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f06c 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:38.040981 [ 5117 ] {87874e57-1dc7-4c31-9b5d-669a5473954d} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 COMMENT \'5\' MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 49, line 120) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 COMMENT \'5\' MODIFY SETTING max_compress_block_size = 20000');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:784: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f06c 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:38.079035 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 COMMENT \'5\' MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:784: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f06c 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:38.223659 [ 16756 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778c58 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168167bf 10. /build/src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000001680ff45 11. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:12:38.233593 [ 12979 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:12:38.235244 [ 16756 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x0000000016810069 5. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 6. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 2025.07.13 02:12:38.284604 [ 5117 ] {33967883-5d6d-4bc6-ab67-242fc61712d2} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 CODEC(ZSTD) MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 50, line 121) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 CODEC(ZSTD) MODIFY SETTING max_compress_block_size = 20000');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:784: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f06c 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:38.335159 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 CODEC(ZSTD) MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:784: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f06c 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:38.552512 [ 5117 ] {cb9b66b1-88d9-4be6-bf8c-ba04e7e6326f} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 STATISTICS(tdigest) MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 51, line 122) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 STATISTICS(tdigest) MODIFY SETTING max_compress_block_size = 20000');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:784: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f06c 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:38.568958 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 STATISTICS(tdigest) MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:784: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f06c 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:38.667233 [ 30811 ] {afb08d9d-22b0-415b-a708-0cacbefca323} executeQuery: Code: 50. DB::Exception: Unknown data type family: ab. (UNKNOWN_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52448) (comment: 03144_fuzz_quoted_type_name.sql) (query 1, line 5) (in query: create table t (x Array(`ab`)) engine Memory;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/DataTypes/DataTypeFactory.cpp:252: std::function (std::shared_ptr const&)> const* DB::DataTypeFactory::findCreatorByName(String const&) const @ 0x0000000013b0e953 5. /build/src/DataTypes/DataTypeFactory.cpp:125: std::shared_ptr DB::DataTypeFactory::getImpl(String const&, std::shared_ptr const&) const @ 0x0000000013b0e24d 6. /build/src/DataTypes/DataTypeFactory.cpp:91: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000013b0dcfe 7. /build/src/DataTypes/DataTypeArray.cpp:104: DB::create(std::shared_ptr const&) @ 0x0000000013afe497 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013b0e25b 9. /build/src/DataTypes/DataTypeFactory.cpp:91: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000013b0dcfe 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:569: DB::InterpreterCreateQuery::getColumnType(DB::ASTColumnDeclaration const&, DB::LoadingStrictnessLevel, bool) @ 0x000000001480a797 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:625: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000001480ac8f 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001480c764 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000001481759b 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:12:38.683171 [ 30811 ] {} TCPHandler: Code: 50. DB::Exception: Unknown data type family: ab. (UNKNOWN_TYPE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/DataTypes/DataTypeFactory.cpp:252: std::function (std::shared_ptr const&)> const* DB::DataTypeFactory::findCreatorByName(String const&) const @ 0x0000000013b0e953 5. /build/src/DataTypes/DataTypeFactory.cpp:125: std::shared_ptr DB::DataTypeFactory::getImpl(String const&, std::shared_ptr const&) const @ 0x0000000013b0e24d 6. /build/src/DataTypes/DataTypeFactory.cpp:91: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000013b0dcfe 7. /build/src/DataTypes/DataTypeArray.cpp:104: DB::create(std::shared_ptr const&) @ 0x0000000013afe497 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013b0e25b 9. /build/src/DataTypes/DataTypeFactory.cpp:91: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000013b0dcfe 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:569: DB::InterpreterCreateQuery::getColumnType(DB::ASTColumnDeclaration const&, DB::LoadingStrictnessLevel, bool) @ 0x000000001480a797 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:625: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000001480ac8f 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001480c764 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000001481759b 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:12:38.802580 [ 5117 ] {264e48ef-1bce-438f-82f7-349788c37a20} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 TTL toDate(\'2025-01-01\') + toIntervalDay(x) MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 52, line 123) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 TTL toDate(\'2025-01-01\') + toIntervalDay(x) MODIFY SETTING max_compress_block_size = 20000');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:784: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f06c 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:38.861458 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 TTL toDate(\'2025-01-01\') + toIntervalDay(x) MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:784: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f06c 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:39.008617 [ 5117 ] {d1f3b79d-7c5c-4e63-949e-90be9810a776} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 COLLATE binary MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 53, line 124) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 COLLATE binary MODIFY SETTING max_compress_block_size = 20000');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:784: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f06c 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:39.018253 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 COLLATE binary MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:784: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f06c 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:39.061204 [ 30811 ] {ff05cf10-7fef-442d-af23-151a78223a42} executeQuery: Code: 50. DB::Exception: Unknown data type family: ab. (UNKNOWN_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52448) (comment: 03144_fuzz_quoted_type_name.sql) (query 2, line 6) (in query: create table t (x `ab`) engine Memory;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/DataTypes/DataTypeFactory.cpp:252: std::function (std::shared_ptr const&)> const* DB::DataTypeFactory::findCreatorByName(String const&) const @ 0x0000000013b0e953 5. /build/src/DataTypes/DataTypeFactory.cpp:125: std::shared_ptr DB::DataTypeFactory::getImpl(String const&, std::shared_ptr const&) const @ 0x0000000013b0e24d 6. /build/src/DataTypes/DataTypeFactory.cpp:91: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000013b0dcfe 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:569: DB::InterpreterCreateQuery::getColumnType(DB::ASTColumnDeclaration const&, DB::LoadingStrictnessLevel, bool) @ 0x000000001480a797 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:625: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000001480ac8f 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001480c764 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000001481759b 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 14. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 15. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 20. ? @ 0x00007f7210eb6ac3 21. ? @ 0x00007f7210f48850 2025.07.13 02:12:39.144424 [ 30811 ] {} TCPHandler: Code: 50. DB::Exception: Unknown data type family: ab. (UNKNOWN_TYPE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/DataTypes/DataTypeFactory.cpp:252: std::function (std::shared_ptr const&)> const* DB::DataTypeFactory::findCreatorByName(String const&) const @ 0x0000000013b0e953 5. /build/src/DataTypes/DataTypeFactory.cpp:125: std::shared_ptr DB::DataTypeFactory::getImpl(String const&, std::shared_ptr const&) const @ 0x0000000013b0e24d 6. /build/src/DataTypes/DataTypeFactory.cpp:91: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000013b0dcfe 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:569: DB::InterpreterCreateQuery::getColumnType(DB::ASTColumnDeclaration const&, DB::LoadingStrictnessLevel, bool) @ 0x000000001480a797 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:625: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000001480ac8f 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001480c764 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000001481759b 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 14. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 15. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 20. ? @ 0x00007f7210eb6ac3 21. ? @ 0x00007f7210f48850 2025.07.13 02:12:39.151851 [ 16763 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000013779f8b 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000137794b8 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778bc3 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678d325 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:12:39.240843 [ 5117 ] {79d78b2b-fd42-4c5f-8996-252084df7ddf} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 SETTINGS (some_setting = 2) MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 54, line 125) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 SETTINGS (some_setting = 2) MODIFY SETTING max_compress_block_size = 20000');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:784: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f06c 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:39.262637 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 SETTINGS (some_setting = 2) MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:784: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f06c 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:39.474780 [ 5117 ] {037df43e-f0d3-4e0c-a4af-bebe7af71298} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 PRIMARY KEY MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 55, line 126) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 PRIMARY KEY MODIFY SETTING max_compress_block_size = 20000');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:784: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f06c 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:39.486537 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'MODIFY SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 PRIMARY KEY MODIFY SETTING max_compress_block_size = 20000'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:784: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f06c 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:40.203505 [ 16756 ] {b979589a-3ef8-48c8-b49b-d98ce45667a1} executeQuery: Code: 43. DB::Exception: mapAdd only accepts maps: In scope SELECT mapAdd([1], [1]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52474) (comment: 01318_map_add_map_subtract.sql) (query 3, line 4) (in query: -- mapAdd select mapAdd([1], [1]);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/array/mapOp.cpp:168: DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000f7b912d 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:12:40.236611 [ 5117 ] {baa502dc-c970-4ccc-9cfd-6799ab0b4d89} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 RESET SETTING max_compress_block_size'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 57, line 129) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 RESET SETTING max_compress_block_size');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:791: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f17a 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:40.239562 [ 16756 ] {} TCPHandler: Code: 43. DB::Exception: mapAdd only accepts maps: In scope SELECT mapAdd([1], [1]). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/array/mapOp.cpp:168: DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000f7b912d 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:12:40.286351 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 RESET SETTING max_compress_block_size'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:791: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f17a 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:40.480279 [ 16756 ] {75d1aa1d-df8f-423f-b546-06197ee4933d} executeQuery: Code: 42. DB::Exception: mapAdd accepts at least two maps or map tuples: In scope SELECT mapAdd(([1], [1])). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52474) (comment: 01318_map_add_map_subtract.sql) (query 4, line 6) (in query: select mapAdd(([1], [1]));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/array/mapOp.cpp:162: DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000f7b908f 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:12:40.492155 [ 5117 ] {ce350777-32e3-4405-9f97-8c7ea8413827} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y DEFAULT 2 RESET SETTING max_compress_block_size'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 58, line 130) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y DEFAULT 2 RESET SETTING max_compress_block_size');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:791: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f17a 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:40.525515 [ 16756 ] {} TCPHandler: Code: 42. DB::Exception: mapAdd accepts at least two maps or map tuples: In scope SELECT mapAdd(([1], [1])). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/array/mapOp.cpp:162: DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000f7b908f 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:12:40.526050 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y DEFAULT 2 RESET SETTING max_compress_block_size'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:791: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f17a 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:40.794134 [ 5117 ] {7e07b6e2-1bee-42c7-aeac-5b052851efaa} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y MATERIALIZED 3 RESET SETTING max_compress_block_size'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 59, line 131) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y MATERIALIZED 3 RESET SETTING max_compress_block_size');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:791: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f17a 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:40.844968 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y MATERIALIZED 3 RESET SETTING max_compress_block_size'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:791: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f17a 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:40.966174 [ 16756 ] {39cbc174-1c1e-4581-9606-6e16e6f567cd} executeQuery: Code: 43. DB::Exception: Expected same UInt8 type for all keys in mapAdd: In scope SELECT mapAdd(([1], [1]), map) FROM tab. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52474) (comment: 01318_map_add_map_subtract.sql) (query 5, line 7) (in query: select mapAdd(([1], [1]), map) from tab;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/array/mapOp.cpp:65: DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::checkTypes(std::shared_ptr&, std::shared_ptr&, std::shared_ptr const&, std::shared_ptr&) const @ 0x000000000f8057eb 5. /build/src/Functions/array/mapOp.cpp:122: DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000f7b84a1 6. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:12:40.992829 [ 16756 ] {} TCPHandler: Code: 43. DB::Exception: Expected same UInt8 type for all keys in mapAdd: In scope SELECT mapAdd(([1], [1]), map) FROM tab. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/array/mapOp.cpp:65: DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::checkTypes(std::shared_ptr&, std::shared_ptr&, std::shared_ptr const&, std::shared_ptr&) const @ 0x000000000f8057eb 5. /build/src/Functions/array/mapOp.cpp:122: DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000f7b84a1 6. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:12:40.998485 [ 5117 ] {9ebd2d6c-6aa1-4cd7-8509-af4c50f55b23} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y EPHEMERAL 4 RESET SETTING max_compress_block_size'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 60, line 132) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y EPHEMERAL 4 RESET SETTING max_compress_block_size');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:791: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f17a 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:41.016086 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y EPHEMERAL 4 RESET SETTING max_compress_block_size'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:791: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f17a 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:41.201666 [ 5117 ] {aaeb36c8-9728-432d-8292-9370018a6018} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y COMMENT \'5\' RESET SETTING max_compress_block_size'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 61, line 133) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y COMMENT \'5\' RESET SETTING max_compress_block_size');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:791: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f17a 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:41.230695 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y COMMENT \'5\' RESET SETTING max_compress_block_size'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:791: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f17a 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:41.313681 [ 5117 ] {11a24b06-fffa-4286-b6d3-a4e4f8ca40fd} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y CODEC(ZSTD) RESET SETTING max_compress_block_size'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 62, line 134) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y CODEC(ZSTD) RESET SETTING max_compress_block_size');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:791: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f17a 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:41.333991 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y CODEC(ZSTD) RESET SETTING max_compress_block_size'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:791: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f17a 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:41.419916 [ 16756 ] {d02cd85b-bcd3-499f-a0a8-307e671da442} executeQuery: Code: 43. DB::Exception: All value types in mapAdd should be promotable to UInt64, got Int64: In scope SELECT mapAdd(([toUInt64(1)], [1]), map) FROM tab. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52474) (comment: 01318_map_add_map_subtract.sql) (query 6, line 8) (in query: select mapAdd(([toUInt64(1)], [1]), map) from tab;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/array/mapOp.cpp:77: DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::checkTypes(std::shared_ptr&, std::shared_ptr&, std::shared_ptr const&, std::shared_ptr&) const @ 0x000000000f805937 5. /build/src/Functions/array/mapOp.cpp:122: DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000f7b84a1 6. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:12:41.434381 [ 16756 ] {} TCPHandler: Code: 43. DB::Exception: All value types in mapAdd should be promotable to UInt64, got Int64: In scope SELECT mapAdd(([toUInt64(1)], [1]), map) FROM tab. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/array/mapOp.cpp:77: DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::checkTypes(std::shared_ptr&, std::shared_ptr&, std::shared_ptr const&, std::shared_ptr&) const @ 0x000000000f805937 5. /build/src/Functions/array/mapOp.cpp:122: DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000f7b84a1 6. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:12:41.491210 [ 5117 ] {c54ce488-829e-4392-b6e1-366e1c772cca} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y STATISTICS(tdigest) RESET SETTING max_compress_block_size'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 63, line 135) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y STATISTICS(tdigest) RESET SETTING max_compress_block_size');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:791: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f17a 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:41.518052 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y STATISTICS(tdigest) RESET SETTING max_compress_block_size'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:791: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f17a 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:41.764920 [ 5117 ] {8683c7ef-6e00-4639-a089-44e00e725bbd} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 35 (toDate): toDate('2025-01-01') + toIntervalDay(x) RESET SETTING max_compress_block_size. Expected one of: COLLATE, DEFAULT, MATERIALIZED, ALIAS, EPHEMERAL, AUTO_INCREMENT, COMMENT, CODEC, STATISTICS, TTL, PRIMARY KEY, SETTINGS, REMOVE, MODIFY SETTING, RESET SETTING, FIRST, AFTER, token, Comma, INTO OUTFILE, FORMAT, ParallelWithClause, PARALLEL WITH, end of query: In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y TTL toDate(\'2025-01-01\') + toIntervalDay(x) RESET SETTING max_compress_block_size'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 64, line 136) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y TTL toDate(\'2025-01-01\') + toIntervalDay(x) RESET SETTING max_compress_block_size');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000009fd29ed 3. /build/src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9acc 4. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 5. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:12:41.833697 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Syntax error: failed at position 35 (toDate): toDate('2025-01-01') + toIntervalDay(x) RESET SETTING max_compress_block_size. Expected one of: COLLATE, DEFAULT, MATERIALIZED, ALIAS, EPHEMERAL, AUTO_INCREMENT, COMMENT, CODEC, STATISTICS, TTL, PRIMARY KEY, SETTINGS, REMOVE, MODIFY SETTING, RESET SETTING, FIRST, AFTER, token, Comma, INTO OUTFILE, FORMAT, ParallelWithClause, PARALLEL WITH, end of query: In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y TTL toDate(\'2025-01-01\') + toIntervalDay(x) RESET SETTING max_compress_block_size'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000009fd29ed 3. /build/src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9acc 4. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 5. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:12:41.844167 [ 30862 ] {a8c5843e-92f2-47d6-9157-fbd635427f49} 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]:40068) (comment: 02001_dist_on_dist_WithMergeableStateAfterAggregation.sql) (in query: DROP DATABASE IF EXISTS test_4lzkq45n SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:12:41.867355 [ 30862 ] {a8c5843e-92f2-47d6-9157-fbd635427f49} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:12:41.871213 [ 16756 ] {4c975bac-7afe-4c7f-a896-331a12450adf} executeQuery: Code: 42. DB::Exception: Key and value array should have same amount of elements. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52474) (comment: 01318_map_add_map_subtract.sql) (query 7, line 9) (in query: select mapAdd(([toUInt64(1), 2], [toInt32(1)]), map) from tab;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/array/mapOp.cpp:402: DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f7b757f 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 10. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013ec18ac 11. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013ec09aa 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016b30052 13. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016cdda71 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000130d8a1a 15. /build/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>>&) @ 0x00000000148a05bd 16. /build/src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000001489a16a 17. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 19. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:12:41.916926 [ 16756 ] {} TCPHandler: Code: 42. DB::Exception: Key and value array should have same amount of elements. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/array/mapOp.cpp:402: DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f7b757f 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 10. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013ec18ac 11. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013ec09aa 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016b30052 13. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016cdda71 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000130d8a1a 15. /build/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>>&) @ 0x00000000148a05bd 16. /build/src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000001489a16a 17. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 19. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:12:42.022795 [ 5117 ] {f6b6c0a0-8662-4104-8f17-06d492d423cc} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 39 (binary): binary RESET SETTING max_compress_block_size. Expected one of: COLLATE, DEFAULT, MATERIALIZED, ALIAS, EPHEMERAL, AUTO_INCREMENT, COMMENT, CODEC, STATISTICS, TTL, PRIMARY KEY, SETTINGS, REMOVE, MODIFY SETTING, RESET SETTING, FIRST, AFTER, token, Comma, INTO OUTFILE, FORMAT, ParallelWithClause, PARALLEL WITH, end of query: In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y COLLATE binary RESET SETTING max_compress_block_size'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 65, line 137) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y COLLATE binary RESET SETTING max_compress_block_size');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000009fd29ed 3. /build/src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9acc 4. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 5. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:12:42.038164 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Syntax error: failed at position 39 (binary): binary RESET SETTING max_compress_block_size. Expected one of: COLLATE, DEFAULT, MATERIALIZED, ALIAS, EPHEMERAL, AUTO_INCREMENT, COMMENT, CODEC, STATISTICS, TTL, PRIMARY KEY, SETTINGS, REMOVE, MODIFY SETTING, RESET SETTING, FIRST, AFTER, token, Comma, INTO OUTFILE, FORMAT, ParallelWithClause, PARALLEL WITH, end of query: In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y COLLATE binary RESET SETTING max_compress_block_size'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000009fd29ed 3. /build/src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9acc 4. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 5. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:12:42.265286 [ 5117 ] {852d49d3-f421-4dad-9a01-a0cb6f969ece} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 54 (=): = 2) RESET SETTING max_compress_block_size. Expected one of: list, delimited by binary operators, literal, NULL, NULL, number, Bool, TRUE, FALSE, string literal, combination of maps, arrays, tuples, data type, identifier: In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y SETTINGS (some_setting = 2) RESET SETTING max_compress_block_size'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 66, line 138) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y SETTINGS (some_setting = 2) RESET SETTING max_compress_block_size');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000009fd29ed 3. /build/src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9acc 4. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 5. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:12:42.277391 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Syntax error: failed at position 54 (=): = 2) RESET SETTING max_compress_block_size. Expected one of: list, delimited by binary operators, literal, NULL, NULL, number, Bool, TRUE, FALSE, string literal, combination of maps, arrays, tuples, data type, identifier: In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y SETTINGS (some_setting = 2) RESET SETTING max_compress_block_size'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000009fd29ed 3. /build/src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9acc 4. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 5. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:12:42.539178 [ 5117 ] {85942182-7dfd-4edc-bdf7-162b6d5ef607} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y PRIMARY KEY RESET SETTING max_compress_block_size'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 67, line 139) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y PRIMARY KEY RESET SETTING max_compress_block_size');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:791: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f17a 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:42.551898 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y PRIMARY KEY RESET SETTING max_compress_block_size'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:791: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f17a 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:43.015602 [ 5117 ] {bbb0ea3b-3903-4a7e-8bb7-b78bf2642041} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 DEFAULT 2 RESET SETTING max_compress_block_size'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 69, line 142) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 DEFAULT 2 RESET SETTING max_compress_block_size');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:791: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f17a 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:43.021301 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 DEFAULT 2 RESET SETTING max_compress_block_size'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:791: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f17a 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:43.136867 [ 5117 ] {9d9260c5-bd02-4303-9e04-1137f1d5a31c} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 MATERIALIZED 3 RESET SETTING max_compress_block_size'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 70, line 143) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 MATERIALIZED 3 RESET SETTING max_compress_block_size');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:791: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f17a 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:43.145424 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 MATERIALIZED 3 RESET SETTING max_compress_block_size'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:791: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f17a 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:43.209492 [ 11479 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:12:43.369595 [ 5117 ] {e43c38b7-b816-4fca-a1cf-c43ae5eb097d} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 EPHEMERAL 4 RESET SETTING max_compress_block_size'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 71, line 144) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 EPHEMERAL 4 RESET SETTING max_compress_block_size');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:791: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f17a 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:43.380359 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 EPHEMERAL 4 RESET SETTING max_compress_block_size'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:791: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f17a 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:43.528977 [ 5117 ] {874cd5d4-e5a9-4dcf-b946-70d0e4944a74} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 COMMENT \'5\' RESET SETTING max_compress_block_size'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 72, line 145) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 COMMENT \'5\' RESET SETTING max_compress_block_size');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:791: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f17a 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:43.549324 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 COMMENT \'5\' RESET SETTING max_compress_block_size'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:791: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f17a 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:43.784230 [ 5117 ] {3155c041-15d9-4329-a2f3-f1d89f24b592} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 CODEC(ZSTD) RESET SETTING max_compress_block_size'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 73, line 146) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 CODEC(ZSTD) RESET SETTING max_compress_block_size');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:791: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f17a 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:43.824960 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 CODEC(ZSTD) RESET SETTING max_compress_block_size'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:791: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f17a 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:44.023828 [ 5117 ] {2d1484aa-e6b0-4871-a62b-ab9b3ca971ac} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 STATISTICS(tdigest) RESET SETTING max_compress_block_size'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 74, line 147) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 STATISTICS(tdigest) RESET SETTING max_compress_block_size');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:791: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f17a 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:44.036971 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 STATISTICS(tdigest) RESET SETTING max_compress_block_size'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:791: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f17a 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:44.150129 [ 5117 ] {54ce88e2-3701-4f00-b7d7-5cdba815caa7} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 TTL toDate(\'2025-01-01\') + toIntervalDay(x) RESET SETTING max_compress_block_size'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 75, line 148) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 TTL toDate(\'2025-01-01\') + toIntervalDay(x) RESET SETTING max_compress_block_size');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:791: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f17a 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:44.169989 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 TTL toDate(\'2025-01-01\') + toIntervalDay(x) RESET SETTING max_compress_block_size'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:791: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f17a 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:44.367084 [ 5117 ] {861c0950-7825-4417-a3df-bef3a2fde8e0} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 COLLATE binary RESET SETTING max_compress_block_size'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 76, line 149) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 COLLATE binary RESET SETTING max_compress_block_size');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:791: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f17a 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:44.398452 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 COLLATE binary RESET SETTING max_compress_block_size'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:791: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f17a 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:44.542878 [ 5117 ] {af7cb2da-3cc5-4106-8fe6-8a37774fff7a} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 SETTINGS (some_setting = 2) RESET SETTING max_compress_block_size'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 77, line 150) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 SETTINGS (some_setting = 2) RESET SETTING max_compress_block_size');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:791: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f17a 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:44.565286 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 SETTINGS (some_setting = 2) RESET SETTING max_compress_block_size'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:791: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f17a 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:44.725201 [ 5117 ] {76b5315e-ebca-46cc-b062-bf6dd7c78e78} executeQuery: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 PRIMARY KEY RESET SETTING max_compress_block_size'). (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42568) (comment: 03231_alter_no_properties_before_remove_modify_reset.sql) (query 78, line 151) (in query: SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 PRIMARY KEY RESET SETTING max_compress_block_size');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:791: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f17a 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:44.741493 [ 5117 ] {} TCPHandler: Code: 62. DB::Exception: Cannot specify column properties before 'RESET SETTING': In scope SELECT formatQuery('ALTER TABLE a MODIFY COLUMN y Int64 PRIMARY KEY RESET SETTING max_compress_block_size'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Parsers/ParserAlterQuery.cpp:757: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()(std::basic_string_view>) const @ 0x000000001795fffd 5. /build/src/Parsers/ParserAlterQuery.cpp:791: DB::ParserAlterCommand::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000001795f17a 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 7. /build/src/Parsers/ParserAlterQuery.cpp:1028: DB::ParserAlterCommandList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017960123 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 9. /build/src/Parsers/ParserAlterQuery.cpp:1081: DB::ParserAlterQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000179606bb 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 11. /build/src/Parsers/ParserQueryWithOutput.cpp:87: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017987732 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 13. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017980da6 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017959c50 15. /build/src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8a20 16. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 17. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 18. /build/src/Functions/formatQuery.cpp:123: DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae81b 19. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 20. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:12:47.548646 [ 3623 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000118cbf6e 8. /build/src/Interpreters/DatabaseCatalog.cpp:1360: DB::DatabaseCatalog::dropTablesParallel(std::vector, std::allocator>>) @ 0x0000000014421059 9. /build/src/Interpreters/DatabaseCatalog.cpp:1382: DB::DatabaseCatalog::dropTableDataTask() @ 0x000000001442155c 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013882414 11. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000138854aa 12. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000013885c47 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 14. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:12:47.635987 [ 16756 ] {a64fac68-fa7d-4a0a-ad08-cce15e4af021} executeQuery: Code: 43. DB::Exception: Illegal column type Float32 for keys in arguments of function mapAdd: In scope SELECT mapAdd(([toFloat32(1), 2], [toFloat64(1.1), 1]), ([toFloat32(1), 2], [2.2, 1])) AS res, toTypeName(res). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52474) (comment: 01318_map_add_map_subtract.sql) (query 21, line 30) (in query: select mapAdd(([toFloat32(1), 2], [toFloat64(1.1), 1]), ([toFloat32(1), 2], [2.2, 1])) as res, toTypeName(res);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/array/mapOp.cpp:443: DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f7b7e86 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:12:47.663737 [ 16756 ] {} TCPHandler: Code: 43. DB::Exception: Illegal column type Float32 for keys in arguments of function mapAdd: In scope SELECT mapAdd(([toFloat32(1), 2], [toFloat64(1.1), 1]), ([toFloat32(1), 2], [2.2, 1])) AS res, toTypeName(res). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/array/mapOp.cpp:443: DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f7b7e86 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:12:48.038008 [ 16756 ] {57e23f74-0b5c-4757-9dd7-e657f1581eb5} executeQuery: Code: 43. DB::Exception: All value types in mapAdd should be either or float or integer: In scope SELECT mapAdd(([1, 2], [toFloat64(1.1), 1]), ([1, 2], [1, 1])) AS res, toTypeName(res). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52474) (comment: 01318_map_add_map_subtract.sql) (query 22, line 31) (in query: select mapAdd(([1, 2], [toFloat64(1.1), 1]), ([1, 2], [1, 1])) as res, toTypeName(res);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/array/mapOp.cpp:72: DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::checkTypes(std::shared_ptr&, std::shared_ptr&, std::shared_ptr const&, std::shared_ptr&) const @ 0x000000000f805884 5. /build/src/Functions/array/mapOp.cpp:122: DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000f7b84a1 6. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:12:48.054240 [ 16756 ] {} TCPHandler: Code: 43. DB::Exception: All value types in mapAdd should be either or float or integer: In scope SELECT mapAdd(([1, 2], [toFloat64(1.1), 1]), ([1, 2], [1, 1])) AS res, toTypeName(res). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/array/mapOp.cpp:72: DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::checkTypes(std::shared_ptr&, std::shared_ptr&, std::shared_ptr const&, std::shared_ptr&) const @ 0x000000000f805884 5. /build/src/Functions/array/mapOp.cpp:122: DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000f7b84a1 6. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:12:48.393112 [ 5095 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:12:48.507961 [ 3543 ] {33d9658c-af41-4dfb-be68-d5b982890f62} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 2.99 MiB (attempt to allocate chunk of 0.00 B), maximum: 47.68 MiB: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39404) (comment: 01062_pm_all_join_with_block_continuation.sql) (query 13, line 37) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x000000000fb2dd39 4. /build/src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2cb67 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2c5bf 6. /build/src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x00000000144ae14c 7. /build/src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x00000000144b7fac 8. /build/src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000016b170dc 9. /build/src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000016b14746 10. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 11. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 12. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 13. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 14. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 15. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 17. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:12:48.574218 [ 3543 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 2.99 MiB (attempt to allocate chunk of 0.00 B), maximum: 47.68 MiB: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x000000000fb2dd39 4. /build/src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2cb67 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2c5bf 6. /build/src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x00000000144ae14c 7. /build/src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x00000000144b7fac 8. /build/src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000016b170dc 9. /build/src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000016b14746 10. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 11. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 12. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 13. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 14. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 15. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 17. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:12:53.065669 [ 4126 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda7a6 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000118cbf6e 8. /build/src/Storages/StorageBuffer.cpp:920: DB::StorageBuffer::flushAllBuffers(bool) @ 0x0000000015f9bd56 9. /build/src/Storages/StorageBuffer.cpp:1094: DB::StorageBuffer::backgroundFlush() @ 0x0000000015f9f5b2 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013882414 11. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000138854aa 12. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000013885c47 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 14. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:12:53.260813 [ 3543 ] {9e7043ea-f8ba-4719-b7b8-7c99900afe2c} 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]:60616) (comment: 01732_race_condition_storage_join_long.sh) (query 1, line 2) (in query: SELECT * FROM storage_join_race FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 9. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:12:53.283481 [ 3543 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 9. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:12:53.443946 [ 12982 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:12:58.456683 [ 12984 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:12:59.143945 [ 4275 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {016194a2-95fd-40f1-8fd3-ef5d9a70e9d6::all_1_6_1}: Code: 241. DB::Exception: Thread memory tracker: fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000000fb2dc4b 4. /build/src/Common/MemoryTracker.cpp:196: MemoryTracker::injectFault() const @ 0x000000000fb2b6cd 5. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:153: DB::MergePlainMergeTreeTask::finish() @ 0x0000000016593639 6. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:72: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000016592af2 7. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 8. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:12:59.758637 [ 16784 ] {7711ce51-7990-4841-8ddd-952322deb6e0} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 03230_show_create_query_identifier_quoting_style.sql) (in query: /* ddl_entry=query-0000000009 */ TRUNCATE DICTIONARY test_a5n6ct77.uk_mortgage_rates_dict), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833ede 5. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 7. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 9. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 10. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 11. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 12. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 13. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 14. /build/src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833287 15. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 16. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 17. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 18. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:12:59.898341 [ 16784 ] {7711ce51-7990-4841-8ddd-952322deb6e0} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52234) (comment: 03230_show_create_query_identifier_quoting_style.sql) (query 77, line 382) (in query: DROP DICTIONARY uk_mortgage_rates_dict;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833ede 5. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 7. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 9. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 10. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 11. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 12. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 13. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 14. /build/src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833287 15. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 16. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 17. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 18. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:12:59.959462 [ 16784 ] {} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833ede 5. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 7. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 9. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 10. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 11. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 12. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 13. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 14. /build/src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833287 15. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 16. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 17. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 18. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:13:00.213972 [ 4281 ] {6d4106c1-0ccc-49c3-bcf5-9dd3e6edc5f6::202507_1_130_26} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x00000000163993d1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016396620 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001639641f 10. /build/src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000163b2bd7 11. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x00000000162ea22d 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x00000000162e6974 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x00000000163d9d66 14. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:159: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::Block, DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr, std::shared_ptr, std::optional, bool, bool) @ 0x00000000163d3337 15. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:se190107] const&, std::shared_ptr, std::optional, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x00000000163d9212 16. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x00000000163d553a 17. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:383: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000163d7ceb 18. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016cf6870 19. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 20. /build/src/Storages/MergeTree/MergeTask.cpp:1910: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() const @ 0x00000000161f8487 21. /build/src/Storages/MergeTree/MergeTask.cpp:567: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000161f2613 22. /build/src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000161f9939 23. /build/src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000161ffd8a 24. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000016592b05 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 26. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 28. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 30. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 31. ? @ 0x00007f7210eb6ac3 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:00.268281 [ 4281 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6d4106c1-0ccc-49c3-bcf5-9dd3e6edc5f6::202507_1_130_26}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x00000000163993d1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016396620 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001639641f 10. /build/src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000163b2bd7 11. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x00000000162ea22d 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x00000000162e6974 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x00000000163d9d66 14. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:159: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::Block, DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr, std::shared_ptr, std::optional, bool, bool) @ 0x00000000163d3337 15. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:se190107] const&, std::shared_ptr, std::optional, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x00000000163d9212 16. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x00000000163d553a 17. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:383: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000163d7ceb 18. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016cf6870 19. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 20. /build/src/Storages/MergeTree/MergeTask.cpp:1910: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() const @ 0x00000000161f8487 21. /build/src/Storages/MergeTree/MergeTask.cpp:567: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000161f2613 22. /build/src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000161f9939 23. /build/src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000161ffd8a 24. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000016592b05 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 26. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 28. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 30. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 31. ? @ 0x00007f7210eb6ac3 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:00.548368 [ 30862 ] {3e5b8fd5-e57c-4c7b-9deb-36de84cc977e} executeQuery: Code: 57. DB::Exception: Table test_hr3d9djn.t already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60794) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:13:00.556796 [ 30862 ] {} TCPHandler: Code: 57. DB::Exception: Table test_hr3d9djn.t already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:13:00.874420 [ 3543 ] {ffa84d17-035e-4df7-8021-0012d58c61ae} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33820) (comment: 03230_show_create_query_identifier_quoting_style.sql) (in query: DROP DATABASE IF EXISTS test_a5n6ct77 SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833ede 5. /build/src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835a47 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:13:00.877930 [ 3543 ] {ffa84d17-035e-4df7-8021-0012d58c61ae} DynamicQueryHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833ede 5. /build/src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835a47 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:01.122676 [ 6612 ] {ee08bcdc-5cc7-4a6f-b335-38f0e3b97a48} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:34dcbd9e-d829-4820-8cc4-944bf0cfe481'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33828) (comment: 01780_column_sparse_filter.sql) (in query: CREATE DATABASE IF NOT EXISTS test_exkv6e86 ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:13:01.125257 [ 6612 ] {ee08bcdc-5cc7-4a6f-b335-38f0e3b97a48} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:34dcbd9e-d829-4820-8cc4-944bf0cfe481'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:01.387797 [ 31799 ] {4a3cfe86-49b8-4c05-9b1b-1f3bd414a37a} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:a3411432-7965-421d-87fb-c3585761e663'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33844) (comment: 02882_primary_key_index_in_function_different_types.sql) (in query: CREATE DATABASE IF NOT EXISTS test_u3c2nmtp ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:13:01.409263 [ 31799 ] {4a3cfe86-49b8-4c05-9b1b-1f3bd414a37a} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:a3411432-7965-421d-87fb-c3585761e663'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:01.758983 [ 31792 ] {fcac8325-8aa6-4252-9d67-4d9d243cf614} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:aa8e870e-101a-43bd-9850-cb6e2fca149b'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33858) (comment: 02540_date_column_consistent_insert_behaviour.sql) (in query: CREATE DATABASE IF NOT EXISTS test_hv7rgdhw ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:13:01.780668 [ 31792 ] {fcac8325-8aa6-4252-9d67-4d9d243cf614} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:aa8e870e-101a-43bd-9850-cb6e2fca149b'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:02.162630 [ 31831 ] {288545a1-7cdb-4ee5-9f69-4266f0a34504} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:a13f7941-f81c-4850-aefd-d8ef22225eb2'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33868) (comment: 02353_simdjson_buffer_overflow.sql) (in query: CREATE DATABASE IF NOT EXISTS test_8huflzim ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:13:02.189379 [ 31831 ] {288545a1-7cdb-4ee5-9f69-4266f0a34504} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:a13f7941-f81c-4850-aefd-d8ef22225eb2'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:02.585931 [ 6612 ] {4027ad7b-3907-415e-9ecf-06ba1c334420} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:35659d81-f976-4c71-8b9e-a4fbf475b834'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33870) (comment: 00167_settings_inside_query.sql) (in query: CREATE DATABASE IF NOT EXISTS test_6ne5hpqi ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:13:02.603228 [ 6612 ] {4027ad7b-3907-415e-9ecf-06ba1c334420} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:35659d81-f976-4c71-8b9e-a4fbf475b834'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:02.928182 [ 6612 ] {87a1d0fc-3a33-4419-804f-e04ccb20eb0c} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:15c7adbe-413c-49b7-b895-e0d78d8541be'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33872) (comment: 02797_join_nested_lowcardinality_convert.gen.sql) (in query: CREATE DATABASE IF NOT EXISTS test_pgprnl4b ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:13:02.930595 [ 6612 ] {87a1d0fc-3a33-4419-804f-e04ccb20eb0c} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:15c7adbe-413c-49b7-b895-e0d78d8541be'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:03.323284 [ 31831 ] {f0e27cdf-2dc3-4c4a-8450-1d94057d6701} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:19921c96-4022-41da-9c74-847aaad58a2b'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33886) (comment: 02117_custom_separated_with_names_and_types.sh) (in query: CREATE DATABASE IF NOT EXISTS test_abpl6d7s ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:13:03.343216 [ 31831 ] {f0e27cdf-2dc3-4c4a-8450-1d94057d6701} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:19921c96-4022-41da-9c74-847aaad58a2b'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:03.604858 [ 12991 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:13:03.804220 [ 31788 ] {a88e3f56-bacd-4224-9a49-b5e44ba06011} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:8d265e6d-923e-4125-8392-4f8f82db6d0e'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33898) (comment: 01470_columns_transformers2.sql) (in query: CREATE DATABASE IF NOT EXISTS test_v8498esk ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:13:03.869018 [ 31788 ] {a88e3f56-bacd-4224-9a49-b5e44ba06011} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:8d265e6d-923e-4125-8392-4f8f82db6d0e'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:04.252304 [ 31831 ] {4294afc2-09b0-4f44-953e-0201b66c1b75} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:dcd9fc1b-4b4c-4862-98d5-660f8dc28699'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33900) (comment: 00296_url_parameters.sql) (in query: CREATE DATABASE IF NOT EXISTS test_6g1yk2cm ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:13:04.280677 [ 31831 ] {4294afc2-09b0-4f44-953e-0201b66c1b75} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:dcd9fc1b-4b4c-4862-98d5-660f8dc28699'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:04.658018 [ 5998 ] {cb05d72c-796f-43f7-b1be-322d78ab7d9d} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:4037844b-12e2-483c-a9bb-526162494ab6'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33902) (comment: 02968_mysql_prefer_column_name_to_alias.sh) (in query: CREATE DATABASE IF NOT EXISTS test_zoyfhbed ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:13:04.722138 [ 5998 ] {cb05d72c-796f-43f7-b1be-322d78ab7d9d} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:4037844b-12e2-483c-a9bb-526162494ab6'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:05.173980 [ 31792 ] {c4354729-ae7a-4279-9976-4b530465eea3} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:cc2a8fe5-4cd9-47f1-9d62-54bb5b6e549e'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33916) (comment: 00726_materialized_view_concurrent.sql) (in query: CREATE DATABASE IF NOT EXISTS test_86ev5sij ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:13:05.195472 [ 31792 ] {c4354729-ae7a-4279-9976-4b530465eea3} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:cc2a8fe5-4cd9-47f1-9d62-54bb5b6e549e'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:05.691869 [ 5998 ] {0aea6bf3-2811-42cf-beef-3a3109255ba3} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:c3bf1b54-a3ff-4900-9874-503bd0ec188d'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33932) (comment: 02918_optimize_count_for_merge_tables.sql) (in query: CREATE DATABASE IF NOT EXISTS test_jsz9pzwz ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:13:05.702223 [ 5998 ] {0aea6bf3-2811-42cf-beef-3a3109255ba3} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:c3bf1b54-a3ff-4900-9874-503bd0ec188d'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:06.027219 [ 6612 ] {49c3f98a-a320-4242-b048-f2112f66e4b4} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:d8c6f7ff-9cd8-48bc-94e8-ef06721c8c73'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33936) (comment: 02535_analyzer_limit_offset.sql) (in query: CREATE DATABASE IF NOT EXISTS test_qukcu8wg ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:13:06.033683 [ 6612 ] {49c3f98a-a320-4242-b048-f2112f66e4b4} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:d8c6f7ff-9cd8-48bc-94e8-ef06721c8c73'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:06.420160 [ 4922 ] {859bec88-3f3c-4d70-b727-a4730027cb74} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:ed3c67da-0538-4abe-89ea-311cbbb9508f'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33952) (comment: 03224_json_merges_new_type_in_shared_data.sql) (in query: CREATE DATABASE IF NOT EXISTS test_rgvyp2m5 ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:13:06.424078 [ 4922 ] {859bec88-3f3c-4d70-b727-a4730027cb74} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:ed3c67da-0538-4abe-89ea-311cbbb9508f'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:06.597823 [ 27539 ] {4d2acaf7-73da-49b0-b1b0-dec01fcea562} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:73179a14-4d36-4b3b-924c-ad854f68262b'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33966) (comment: 01246_extractAllGroupsVertical.sql) (in query: CREATE DATABASE IF NOT EXISTS test_kolfuu19 ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:13:06.604997 [ 27539 ] {4d2acaf7-73da-49b0-b1b0-dec01fcea562} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:73179a14-4d36-4b3b-924c-ad854f68262b'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:06.808815 [ 31799 ] {e752743f-7f40-48dc-ad0c-1f8e735cd50a} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:cf17043e-04c5-4ff1-bd1b-fe851745e50a'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33968) (comment: 01431_finish_sorting_with_consts.sql) (in query: CREATE DATABASE IF NOT EXISTS test_rlgp5mjp ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:13:06.811184 [ 4267 ] {016194a2-95fd-40f1-8fd3-ef5d9a70e9d6::all_116_121_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x00000000161ee9da 5. /build/src/Storages/MergeTree/MergeTask.cpp:921: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::finalize() const @ 0x00000000161fb47c 6. /build/src/Storages/MergeTree/MergeTask.cpp:882: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000161fb218 7. /build/src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000161f9939 8. /build/src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000161ffd8a 9. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000016592b05 10. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 11. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 13. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:06.819183 [ 31799 ] {e752743f-7f40-48dc-ad0c-1f8e735cd50a} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:cf17043e-04c5-4ff1-bd1b-fe851745e50a'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:06.837985 [ 4281 ] {016194a2-95fd-40f1-8fd3-ef5d9a70e9d6::all_109_115_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x00000000161ee9da 5. /build/src/Storages/MergeTree/MergeTask.cpp:921: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::finalize() const @ 0x00000000161fb47c 6. /build/src/Storages/MergeTree/MergeTask.cpp:882: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000161fb218 7. /build/src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000161f9939 8. /build/src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000161ffd8a 9. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000016592b05 10. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 11. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 13. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:07.048941 [ 27539 ] {df25bfc9-c676-49ff-92b1-4e016def7405} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:ae9f46b5-e7fa-4b98-aad1-8051bf101ef6'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33982) (comment: 00719_format_datetime_rand.sql) (in query: CREATE DATABASE IF NOT EXISTS test_n1qlgptd ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:13:07.068143 [ 27539 ] {df25bfc9-c676-49ff-92b1-4e016def7405} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:ae9f46b5-e7fa-4b98-aad1-8051bf101ef6'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:07.368993 [ 31799 ] {45cd5791-3aac-4169-a47c-f11ea570eb88} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:cbc75ac6-4bde-4b1f-8fd4-d1000bf8a9cb'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33994) (comment: 00502_custom_partitioning_replicated_zookeeper_long.sql) (in query: CREATE DATABASE IF NOT EXISTS test_ynuzmutz ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:13:07.382046 [ 31799 ] {45cd5791-3aac-4169-a47c-f11ea570eb88} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:cbc75ac6-4bde-4b1f-8fd4-d1000bf8a9cb'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:07.507413 [ 3542 ] {bffd535d-0ea6-46ca-a5d8-94618b2e04a0} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:94892016-7a9e-4e0c-bbbe-ebba00d61fec'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34000) (comment: 01070_h3_to_children.sql) (in query: CREATE DATABASE IF NOT EXISTS test_m7pcv99y ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:13:07.516305 [ 3542 ] {bffd535d-0ea6-46ca-a5d8-94618b2e04a0} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:94892016-7a9e-4e0c-bbbe-ebba00d61fec'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:07.780724 [ 31799 ] {70c0b307-e9c3-4d61-bce5-fecfe3769ac2} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:8adceb62-75a3-4f20-a91e-0fe4ea482a16'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34012) (comment: 01913_exact_rows_before_limit_full.sql) (in query: CREATE DATABASE IF NOT EXISTS test_dajzi9jc ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:13:07.798695 [ 31799 ] {70c0b307-e9c3-4d61-bce5-fecfe3769ac2} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:8adceb62-75a3-4f20-a91e-0fe4ea482a16'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:07.940963 [ 3542 ] {e9b54268-2f33-4295-a742-fd707fef465a} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:c3fde83d-f7bd-403d-bb3c-939494bb3506'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34016) (comment: 02240_system_filesystem_cache_table.sh) (in query: CREATE DATABASE IF NOT EXISTS test_718pxt3b ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:13:07.948888 [ 3542 ] {e9b54268-2f33-4295-a742-fd707fef465a} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:c3fde83d-f7bd-403d-bb3c-939494bb3506'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:08.192775 [ 31799 ] {03bee6c4-2c57-4930-ae91-229dcc7ed673} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:4117dbce-0099-43ef-9b1d-b26e6f2745fd'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34024) (comment: 02494_query_cache_min_query_runs.sql) (in query: CREATE DATABASE IF NOT EXISTS test_9p48p34t ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:13:08.197988 [ 31799 ] {03bee6c4-2c57-4930-ae91-229dcc7ed673} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:4117dbce-0099-43ef-9b1d-b26e6f2745fd'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:08.401269 [ 16784 ] {37b4ca13-f82b-407e-84b8-ca0c6aec0001} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:2a270837-cdee-4dab-b652-6d12a73a57fb'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34026) (comment: 01946_test_wrong_host_name_access.sh) (in query: CREATE DATABASE IF NOT EXISTS test_8o2yw30n ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:13:08.406247 [ 16784 ] {37b4ca13-f82b-407e-84b8-ca0c6aec0001} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:2a270837-cdee-4dab-b652-6d12a73a57fb'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:08.475785 [ 11525 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:13:08.699371 [ 4922 ] {53265b2b-0ed5-4fb8-8227-e8469450e028} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:eace8f28-4610-43d3-bd3c-40ec1aee8f7b'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34030) (comment: 01600_parts_states_metrics_long.sh) (in query: CREATE DATABASE IF NOT EXISTS test_rwmy9m03 ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:13:08.714079 [ 4922 ] {53265b2b-0ed5-4fb8-8227-e8469450e028} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:eace8f28-4610-43d3-bd3c-40ec1aee8f7b'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:09.039110 [ 3542 ] {e04f6c43-a4e9-40de-b7d9-4389bb75721c} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:cb616d1a-fbb0-4c5d-b7bf-444b3f7b8f35'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40262) (comment: 02483_capnp_decimals.sh) (in query: CREATE DATABASE IF NOT EXISTS test_t4apymc4 ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:13:09.049265 [ 3542 ] {e04f6c43-a4e9-40de-b7d9-4389bb75721c} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:cb616d1a-fbb0-4c5d-b7bf-444b3f7b8f35'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:09.330784 [ 4922 ] {fe070cde-f1e8-4eda-a69d-90ab22aa11e9} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:0fc8e47b-6276-4d96-bab5-d4af2d19eb07'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40274) (comment: 01910_view_dictionary.sql) (in query: CREATE DATABASE IF NOT EXISTS test_qd4rul31 ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:13:09.350761 [ 4922 ] {fe070cde-f1e8-4eda-a69d-90ab22aa11e9} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:0fc8e47b-6276-4d96-bab5-d4af2d19eb07'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:09.611771 [ 31799 ] {83adc01f-19d2-42e6-bbbc-3a36dd53a223} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:55a3968d-17a4-4a26-8adc-38d3bd1ba293'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40282) (comment: 01358_union_threads_bug.sql) (in query: CREATE DATABASE IF NOT EXISTS test_j72tbjkl ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:13:09.622961 [ 31799 ] {83adc01f-19d2-42e6-bbbc-3a36dd53a223} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:55a3968d-17a4-4a26-8adc-38d3bd1ba293'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:09.929225 [ 4922 ] {50c9dc37-d7e3-405c-8597-587475d26d0f} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:4468f729-c664-4bce-9251-5a9b0cb98de9'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40294) (comment: 02940_system_stacktrace_optimizations.sh) (in query: CREATE DATABASE IF NOT EXISTS test_ivwczfwz ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:13:09.995640 [ 4922 ] {50c9dc37-d7e3-405c-8597-587475d26d0f} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:4468f729-c664-4bce-9251-5a9b0cb98de9'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:10.261621 [ 31831 ] {6e7dbba6-b6dc-4548-ae86-3722258de0d1} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:bb573f17-9c37-4d86-9500-d4f80841e61e'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40298) (comment: 02293_arrow_dictionary_indexes.sql) (in query: CREATE DATABASE IF NOT EXISTS test_q7wj7r0k ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:13:10.267044 [ 31831 ] {6e7dbba6-b6dc-4548-ae86-3722258de0d1} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:bb573f17-9c37-4d86-9500-d4f80841e61e'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:10.493544 [ 3542 ] {f55fb990-add7-4b4d-9fe9-8f6243128770} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:cfd043e1-cd12-4f43-b11b-8704b49d571f'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40308) (comment: 01302_aggregate_state_exception_memory_leak.sh) (in query: CREATE DATABASE IF NOT EXISTS test_i6rclhby ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:13:10.497669 [ 3542 ] {f55fb990-add7-4b4d-9fe9-8f6243128770} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:cfd043e1-cd12-4f43-b11b-8704b49d571f'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:10.628017 [ 16784 ] {fa2bec80-6f7b-4ea0-955e-37401ff70968} executeQuery: Code: 57. DB::Exception: Table test_3.welch_ttest already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46532) (comment: 01558_ttest.sql) (query 7, line 10) (in query: CREATE TABLE welch_ttest (left Float64, right Float64) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:13:10.642395 [ 16784 ] {} TCPHandler: Code: 57. DB::Exception: Table test_3.welch_ttest already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:13:10.737680 [ 31831 ] {4f3a3cea-0c82-45a2-8250-388dc8b1262f} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:509e2a70-2fa6-4ea8-828a-4c243b7feac8'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40310) (comment: 03101_analyzer_identifiers_3.sql) (in query: CREATE DATABASE IF NOT EXISTS test_772khzx2 ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:13:10.775436 [ 31831 ] {4f3a3cea-0c82-45a2-8250-388dc8b1262f} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:509e2a70-2fa6-4ea8-828a-4c243b7feac8'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:11.082129 [ 31799 ] {1e3def01-a800-4995-bd84-766068b84a17} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:9638977d-f96a-4805-af63-e264f33dfffa'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40320) (comment: 02494_trace_log_profile_events.sh) (in query: CREATE DATABASE IF NOT EXISTS test_e7j7tuqm ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:13:11.091411 [ 31799 ] {1e3def01-a800-4995-bd84-766068b84a17} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:9638977d-f96a-4805-af63-e264f33dfffa'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:11.324498 [ 4922 ] {f76ec87b-3b88-42a9-a6f4-c124a0e70c00} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:0bcb5003-a1fa-4611-ae46-e4c1bf078bef'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40330) (comment: 01007_r1r2_w_r2r1_deadlock.sh) (in query: CREATE DATABASE IF NOT EXISTS test_k0p79q4t ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:13:11.341279 [ 4922 ] {f76ec87b-3b88-42a9-a6f4-c124a0e70c00} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:0bcb5003-a1fa-4611-ae46-e4c1bf078bef'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:11.522779 [ 6608 ] {dccd84c0-e41e-44de-b382-0a098e8625a6} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 77918.137267 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53480) (comment: 01630_simple_aggregate_all_functions_in_summing_merge_tree.sql) (query 9, line 144) (in query: INSERT INTO simple_agf_aggregating_mt SELECT number % 11151 AS a, minState(number), min(number), maxState(number), max(number), sumState(number), sum(number), sumWithOverflowState(number), sumWithOverflow(number), groupBitAndState((number % 3) + 111111110), groupBitAnd((number % 3) + 111111110), groupBitOrState(number + 111111111), groupBitOr(number + 111111111), groupBitXorState(number + 111111111), groupBitXor(number + 111111111), groupArrayArrayState([toUInt64(number % 100)]), groupArrayArray([toUInt64(number % 100)]), groupUniqArrayArrayState([toUInt64(number % 50)]), groupUniqArrayArray([toUInt64(number % 50)]), sumMapState((arrayMap(i -> toString(i), range(13)), arrayMap(i -> (number + i), range(13)))), sumMap((arrayMap(i -> toString(i), range(13)), arrayMap(i -> (number + i), range(13)))), minMapState((arrayMap(i -> toString(i), range(13)), arrayMap(i -> (number + i), range(13)))), minMap((arrayMap(i -> toString(i), range(13)), arrayMap(i -> (number + i), range(13)))), maxMapState((arrayMap(i -> toString(i), range(13)), arrayMap(i -> (number + i), range(13)))), maxMap((arrayMap(i -> toString(i), range(13)), arrayMap(i -> (number + i), range(13)))) FROM numbers(10000) GROUP BY a;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x0000000013ad84ab 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x0000000013ad77ec 5. /build/src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x000000001496af1f 6. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000168d1a5a 7. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0c24 8. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168cfe81 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 2025.07.13 02:13:11.564527 [ 3542 ] {dd6c12fe-c801-4602-8e47-4a4b91a671c7} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:851f61c9-4887-4e80-8fb0-9fe214206816'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40346) (comment: 00002_log_and_exception_messages_formatting.sql) (in query: CREATE DATABASE IF NOT EXISTS test_35trfx75 ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:13:11.575773 [ 3542 ] {dd6c12fe-c801-4602-8e47-4a4b91a671c7} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:851f61c9-4887-4e80-8fb0-9fe214206816'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:11.931450 [ 31831 ] {e5f3121e-b1c4-49a2-8483-cc437997c432} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:6bf184d0-f57d-43fa-a586-6b247a06f5f6'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40348) (comment: 00170_s3_cache.sql) (in query: CREATE DATABASE IF NOT EXISTS test_ze1nwnjj ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:13:11.940439 [ 31831 ] {e5f3121e-b1c4-49a2-8483-cc437997c432} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:6bf184d0-f57d-43fa-a586-6b247a06f5f6'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:12.086071 [ 31793 ] {f298ff18-4d4b-46ef-9081-bd10414ff09a} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:14569420-26de-4ccd-9353-e88722b73acd'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40350) (comment: 02242_arrow_orc_parquet_nullable_schema_inference.sh) (in query: CREATE DATABASE IF NOT EXISTS test_6sa0jh7x ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:13:12.135008 [ 31793 ] {f298ff18-4d4b-46ef-9081-bd10414ff09a} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:14569420-26de-4ccd-9353-e88722b73acd'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:12.367324 [ 3543 ] {7a7384a9-5872-4be3-8158-9d7025ba65ea} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:dcbaa1f1-571a-4b7d-926c-38fa53f5cdb5'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40360) (comment: 00722_inner_join.sql) (in query: CREATE DATABASE IF NOT EXISTS test_nze80w29 ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:13:12.370853 [ 3543 ] {7a7384a9-5872-4be3-8158-9d7025ba65ea} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:dcbaa1f1-571a-4b7d-926c-38fa53f5cdb5'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:12.504694 [ 16784 ] {e24bb4b0-573d-4759-9900-447e6e5b3829} executeQuery: Code: 565. DB::Exception: Too many partitions to read. Current 2, max 1. (TOO_MANY_PARTITIONS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46564) (comment: 01632_max_partitions_to_read.sql) (query 4, line 7) (in query: select * from p order by i;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, long&) @ 0x0000000016324fab 4. /build/src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1015: DB::MergeTreeDataSelectExecutor::checkLimits(DB::MergeTreeData const&, DB::ReadFromMergeTree::AnalysisResult const&, std::shared_ptr const&) @ 0x000000001631fae7 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2142: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d57682 6. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016cf6870 7. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:13:12.613074 [ 16784 ] {} TCPHandler: Code: 565. DB::Exception: Too many partitions to read. Current 2, max 1. (TOO_MANY_PARTITIONS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, long&) @ 0x0000000016324fab 4. /build/src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1015: DB::MergeTreeDataSelectExecutor::checkLimits(DB::MergeTreeData const&, DB::ReadFromMergeTree::AnalysisResult const&, std::shared_ptr const&) @ 0x000000001631fae7 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2142: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d57682 6. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016cf6870 7. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:13:12.727260 [ 3543 ] {5c6a9258-afd0-4918-b358-145674dcc720} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:da928fe9-5303-4e25-91fb-4ef0f26bb1a0'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40376) (comment: 02484_substitute_udf_storage_args.sql) (in query: CREATE DATABASE IF NOT EXISTS test_0rz6wkhc ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:13:12.749707 [ 3543 ] {5c6a9258-afd0-4918-b358-145674dcc720} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:da928fe9-5303-4e25-91fb-4ef0f26bb1a0'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:12.795715 [ 6612 ] {5c15ca0c-0f2c-46ff-b34f-42fa6b566c1d} executeQuery: Code: 57. DB::Exception: Table test_9.test_table already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51480) (comment: 03371_constant_alias_columns.sql) (query 15, line 21) (in query: CREATE TABLE test_table (`a` UInt64, `b` UInt64, `c` UInt64, `d` UInt64, `n` Nested(x String)) ENGINE = MergeTree PARTITION BY b ORDER BY a SETTINGS index_granularity = 59000, min_bytes_for_wide_part = 193792882, 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 = 308270607, compact_parts_max_bytes_to_buffer = 315326523, compact_parts_max_granules_to_buffer = 23, compact_parts_merge_max_bytes_to_prefetch_part = 31212808, merge_max_block_size = 6882, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 845540, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 520524363, index_granularity_bytes = 8302649, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 24, 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 = 23661, primary_key_compress_block_size = 94417, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:13:12.821639 [ 6612 ] {} TCPHandler: Code: 57. DB::Exception: Table test_9.test_table already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:13:12.992446 [ 5998 ] {cbf4e5df-e02e-427d-bd14-d9c2fdb4db63} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:f033fad5-0fe5-473b-b94e-9ca0fe9598fc'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40384) (comment: 00021_3_select_with_in.sql) (in query: CREATE DATABASE IF NOT EXISTS test_njqqbqsn ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:13:13.002982 [ 5998 ] {cbf4e5df-e02e-427d-bd14-d9c2fdb4db63} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '933e750fc1f6:9000:30a9fb95-2869-456a-b4cf-e90abe70abee', current host ID: '933e750fc1f6:9000:f033fad5-0fe5-473b-b94e-9ca0fe9598fc'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000013cd9a39 4. /build/src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013cb5895 5. /build/src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013cb9c14 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001482ca74 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000014807394 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:13.542612 [ 4622 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:13:15.574028 [ 16763 ] {78e95c38-1831-49aa-a796-c82181820347} executeQuery: Code: 43. DB::Exception: Illegal type UInt8 of argument of function arrayShiftLeft, expected String: In scope SELECT arrayShiftLeft(['foo'], 3, 3). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60656) (comment: 02845_arrayShiftRotate.sql) (query 69, line 77) (in query: select arrayShiftLeft(['foo'], 3, 3);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/array/arrayShiftRotate.cpp:81: DB::FunctionArrayShiftRotate, DB::NameArrayShiftLeft>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000f59ebd8 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:15.582819 [ 16763 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type UInt8 of argument of function arrayShiftLeft, expected String: In scope SELECT arrayShiftLeft(['foo'], 3, 3). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/array/arrayShiftRotate.cpp:81: DB::FunctionArrayShiftRotate, DB::NameArrayShiftLeft>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000f59ebd8 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:15.691672 [ 16763 ] {33fff630-cfa1-4a59-b672-c91029d038cd} executeQuery: Code: 43. DB::Exception: Illegal type String of argument of function arrayShiftLeft, expected UInt8: In scope SELECT arrayShiftLeft([1], 3, 'foo'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:60656) (comment: 02845_arrayShiftRotate.sql) (query 70, line 78) (in query: select arrayShiftLeft([1], 3, 'foo');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/array/arrayShiftRotate.cpp:81: DB::FunctionArrayShiftRotate, DB::NameArrayShiftLeft>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000f59ebd8 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:15.708552 [ 16763 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of argument of function arrayShiftLeft, expected UInt8: In scope SELECT arrayShiftLeft([1], 3, 'foo'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/array/arrayShiftRotate.cpp:81: DB::FunctionArrayShiftRotate, DB::NameArrayShiftLeft>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000f59ebd8 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:16.231354 [ 32568 ] {66e828d9-33ee-477a-9848-6395715e50f4} 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]:46634) (comment: 03210_fix_single_value_data_assertion.sql) (query 1, line 1) (in query: SELECT intDiv(number, 2) AS k, sumArgMax(number, number % 20), sumArgMax(number, leftPad(toString(number % 20), 5, '0')), -- Pad with 0 to preserve number ordering sumArgMax(number, [number % 20, number % 20]), sumArgMin(number, number % 20), sumArgMin(number, leftPad(toString(number % 20), 5, '0')), sumArgMin(number, [number % 20, number % 20]), FROM ( SELECT number FROM system.numbers LIMIT 65537 ) GROUP BY k WITH TOTALS ORDER BY k ASC LIMIT 10 SETTINGS group_by_overflow_mode = 'any', totals_mode = 'before_having', max_rows_to_group_by = 100000;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/executeQuery.cpp:1338: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba8300 5. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 6. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 7. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 12. ? @ 0x00007f7210eb6ac3 13. ? @ 0x00007f7210f48850 2025.07.13 02:13:16.254974 [ 32568 ] {} TCPHandler: Code: 731. DB::Exception: use_query_cache and overflow_mode != 'throw' cannot be used together. (QUERY_CACHE_USED_WITH_NON_THROW_OVERFLOW_MODE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/executeQuery.cpp:1338: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba8300 5. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 6. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 7. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 12. ? @ 0x00007f7210eb6ac3 13. ? @ 0x00007f7210f48850 2025.07.13 02:13:18.572203 [ 4622 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:13:18.687986 [ 4622 ] {} ExternalDictionariesLoader: Could not update external dictionary 'd6fbfd16-05c4-4288-b325-142078f64329', leaving the previous version, next update is scheduled at 2025-07-13 02:13:24: 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda7a6 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 9. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:19.677325 [ 30862 ] {c9a89adf-8bd8-41b7-9a28-1641c20c415d} executeQuery: Code: 131. DB::Exception: The string size is too big for function editDistance, should be at most 65536: while executing 'FUNCTION editDistance(randomString(_CAST(131072._Float64, 'Float64'_String)) :: 3, 'abc'_String :: 2) -> editDistance(randomString(_CAST(131072._Float64, 'Float64'_String)), 'abc'_String) UInt64 : 1'. (TOO_LARGE_STRING_SIZE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46630) (comment: 02884_string_distance_function.sql) (query 13, line 16) (in query: SELECT editDistance(randomString(power(2, 17)), 'abc');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000a8668eb 4. /build/src/Functions/FunctionsStringDistance.cpp:245: DB::ByteEditDistanceImpl::process(char const*, unsigned long, char const*, unsigned long) @ 0x000000000a866817 5. /build/src/Functions/FunctionsStringDistance.cpp:67: DB::FunctionStringDistanceImpl>::constantVector(String const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x000000000a866377 6. /build/src/Functions/FunctionsStringDistance.cpp:79: DB::FunctionsStringSimilarity>, DB::NameEditDistance>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a865adc 7. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 8. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 11. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:13:19.727435 [ 30862 ] {} TCPHandler: Code: 131. DB::Exception: The string size is too big for function editDistance, should be at most 65536: while executing 'FUNCTION editDistance(randomString(_CAST(131072._Float64, 'Float64'_String)) :: 3, 'abc'_String :: 2) -> editDistance(randomString(_CAST(131072._Float64, 'Float64'_String)), 'abc'_String) UInt64 : 1'. (TOO_LARGE_STRING_SIZE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000a8668eb 4. /build/src/Functions/FunctionsStringDistance.cpp:245: DB::ByteEditDistanceImpl::process(char const*, unsigned long, char const*, unsigned long) @ 0x000000000a866817 5. /build/src/Functions/FunctionsStringDistance.cpp:67: DB::FunctionStringDistanceImpl>::constantVector(String const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x000000000a866377 6. /build/src/Functions/FunctionsStringDistance.cpp:79: DB::FunctionsStringSimilarity>, DB::NameEditDistance>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a865adc 7. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 8. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 11. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:13:20.114032 [ 30862 ] {7a3bc6e3-a6b8-44e8-8915-454ab23d4034} executeQuery: Code: 131. DB::Exception: The string size is too big for function damerauLevenshteinDistance, should be at most 65536: while executing 'FUNCTION damerauLevenshteinDistance(randomString(_CAST(131072._Float64, 'Float64'_String)) :: 3, 'abc'_String :: 2) -> damerauLevenshteinDistance(randomString(_CAST(131072._Float64, 'Float64'_String)), 'abc'_String) UInt64 : 1'. (TOO_LARGE_STRING_SIZE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46630) (comment: 02884_string_distance_function.sql) (query 14, line 17) (in query: SELECT damerauLevenshteinDistance(randomString(power(2, 17)), 'abc');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000a8668eb 4. /build/src/Functions/FunctionsStringDistance.cpp:306: DB::ByteDamerauLevenshteinDistanceImpl::process(char const*, unsigned long, char const*, unsigned long) @ 0x000000000a8699c2 5. /build/src/Functions/FunctionsStringDistance.cpp:67: DB::FunctionStringDistanceImpl::constantVector(String const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x000000000a869437 6. /build/src/Functions/FunctionsStringDistance.cpp:79: DB::FunctionsStringSimilarity, DB::NameDamerauLevenshteinDistance>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a868b9c 7. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 8. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 11. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:13:20.137457 [ 30862 ] {} TCPHandler: Code: 131. DB::Exception: The string size is too big for function damerauLevenshteinDistance, should be at most 65536: while executing 'FUNCTION damerauLevenshteinDistance(randomString(_CAST(131072._Float64, 'Float64'_String)) :: 3, 'abc'_String :: 2) -> damerauLevenshteinDistance(randomString(_CAST(131072._Float64, 'Float64'_String)), 'abc'_String) UInt64 : 1'. (TOO_LARGE_STRING_SIZE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000a8668eb 4. /build/src/Functions/FunctionsStringDistance.cpp:306: DB::ByteDamerauLevenshteinDistanceImpl::process(char const*, unsigned long, char const*, unsigned long) @ 0x000000000a8699c2 5. /build/src/Functions/FunctionsStringDistance.cpp:67: DB::FunctionStringDistanceImpl::constantVector(String const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x000000000a869437 6. /build/src/Functions/FunctionsStringDistance.cpp:79: DB::FunctionsStringSimilarity, DB::NameDamerauLevenshteinDistance>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a868b9c 7. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 8. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 11. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:13:20.222890 [ 31792 ] {f798e9ab-23c1-4038-ab46-e31e6aa0386c} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date32 for function toHour: while executing 'FUNCTION toHour(__table1.x1 :: 1) -> toHour(__table1.x1) UInt8 : 0'. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46620) (comment: 01921_datatype_date32.sql) (query 18, line 20) (in query: select toHour(x1) from t1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000009fb18cb 4. /build/src/Functions/DateTimeTransforms.cpp:18: DB::throwDate32IsNotSupported(char const*) @ 0x0000000009fb17a5 5. /build/src/Functions/DateTimeTransforms.h:1482: COW::immutable_ptr DB::DateTimeTransformImpl, DB::ToHourImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToHourImpl const&) @ 0x000000000e7688fe 6. /build/src/Functions/FunctionDateOrDateTimeToSomething.h:74: DB::FunctionDateOrDateTimeToSomething, DB::ToHourImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e767d8d 7. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 8. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 11. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:13:20.243478 [ 31792 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date32 for function toHour: while executing 'FUNCTION toHour(__table1.x1 :: 1) -> toHour(__table1.x1) UInt8 : 0'. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000009fb18cb 4. /build/src/Functions/DateTimeTransforms.cpp:18: DB::throwDate32IsNotSupported(char const*) @ 0x0000000009fb17a5 5. /build/src/Functions/DateTimeTransforms.h:1482: COW::immutable_ptr DB::DateTimeTransformImpl, DB::ToHourImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToHourImpl const&) @ 0x000000000e7688fe 6. /build/src/Functions/FunctionDateOrDateTimeToSomething.h:74: DB::FunctionDateOrDateTimeToSomething, DB::ToHourImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e767d8d 7. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 8. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 11. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:13:20.279949 [ 6619 ] {d806e332-9a22-49d9-85c2-e382938413bc} 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]:54610) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/extractGroups.cpp:64: DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b835049 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:13:20.293410 [ 6619 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/extractGroups.cpp:64: DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b835049 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:13:20.600764 [ 30862 ] {7b065db0-053c-45e9-b6b7-9f1e9eccd8cf} executeQuery: Code: 131. DB::Exception: The string size is too big for function jaroSimilarity, should be at most 65536: while executing 'FUNCTION jaroSimilarity(randomString(_CAST(131072._Float64, 'Float64'_String)) :: 3, 'abc'_String :: 2) -> jaroSimilarity(randomString(_CAST(131072._Float64, 'Float64'_String)), 'abc'_String) Float64 : 1'. (TOO_LARGE_STRING_SIZE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46630) (comment: 02884_string_distance_function.sql) (query 15, line 18) (in query: SELECT jaroSimilarity(randomString(power(2, 17)), 'abc');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000a8668eb 4. /build/src/Functions/FunctionsStringDistance.cpp:370: DB::ByteJaroSimilarityImpl::process(char const*, unsigned long, char const*, unsigned long) @ 0x000000000a86d7cc 5. /build/src/Functions/FunctionsStringDistance.cpp:67: DB::FunctionStringDistanceImpl::constantVector(String const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x000000000a86d297 6. /build/src/Functions/FunctionsStringDistance.cpp:79: DB::FunctionsStringSimilarity, DB::NameJaroSimilarity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a86c9f3 7. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 8. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 11. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:13:20.628448 [ 30862 ] {} TCPHandler: Code: 131. DB::Exception: The string size is too big for function jaroSimilarity, should be at most 65536: while executing 'FUNCTION jaroSimilarity(randomString(_CAST(131072._Float64, 'Float64'_String)) :: 3, 'abc'_String :: 2) -> jaroSimilarity(randomString(_CAST(131072._Float64, 'Float64'_String)), 'abc'_String) Float64 : 1'. (TOO_LARGE_STRING_SIZE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000a8668eb 4. /build/src/Functions/FunctionsStringDistance.cpp:370: DB::ByteJaroSimilarityImpl::process(char const*, unsigned long, char const*, unsigned long) @ 0x000000000a86d7cc 5. /build/src/Functions/FunctionsStringDistance.cpp:67: DB::FunctionStringDistanceImpl::constantVector(String const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x000000000a86d297 6. /build/src/Functions/FunctionsStringDistance.cpp:79: DB::FunctionsStringSimilarity, DB::NameJaroSimilarity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a86c9f3 7. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 8. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 11. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:13:20.710994 [ 6619 ] {743419e4-8177-46db-bc2e-855cf5d3f64e} 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]:54610) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/extractAllGroups.h:97: DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b833bea 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:13:20.731638 [ 6619 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/extractAllGroups.h:97: DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b833bea 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:13:20.858699 [ 31792 ] {9208f683-594d-4741-8aa6-98f915a8760b} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date32 for function toMinute: while executing 'FUNCTION toMinute(__table1.x1 :: 1) -> toMinute(__table1.x1) UInt8 : 0'. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46620) (comment: 01921_datatype_date32.sql) (query 20, line 22) (in query: select toMinute(x1) from t1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000009fb18cb 4. /build/src/Functions/DateTimeTransforms.cpp:18: DB::throwDate32IsNotSupported(char const*) @ 0x0000000009fb17a5 5. /build/src/Functions/DateTimeTransforms.h:1541: COW::immutable_ptr DB::DateTimeTransformImpl, DB::ToMinuteImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToMinuteImpl const&) @ 0x000000000e773d7e 6. /build/src/Functions/FunctionDateOrDateTimeToSomething.h:74: DB::FunctionDateOrDateTimeToSomething, DB::ToMinuteImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e77312d 7. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 8. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 11. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:13:20.872438 [ 31792 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date32 for function toMinute: while executing 'FUNCTION toMinute(__table1.x1 :: 1) -> toMinute(__table1.x1) UInt8 : 0'. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000009fb18cb 4. /build/src/Functions/DateTimeTransforms.cpp:18: DB::throwDate32IsNotSupported(char const*) @ 0x0000000009fb17a5 5. /build/src/Functions/DateTimeTransforms.h:1541: COW::immutable_ptr DB::DateTimeTransformImpl, DB::ToMinuteImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToMinuteImpl const&) @ 0x000000000e773d7e 6. /build/src/Functions/FunctionDateOrDateTimeToSomething.h:74: DB::FunctionDateOrDateTimeToSomething, DB::ToMinuteImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e77312d 7. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 8. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 11. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:13:20.906799 [ 30862 ] {a131bbde-15ff-4f33-93d5-c079c06a0a50} executeQuery: Code: 131. DB::Exception: The string size is too big for function jaroWinklerSimilarity, should be at most 65536: while executing 'FUNCTION jaroWinklerSimilarity(randomString(_CAST(131072._Float64, 'Float64'_String)) :: 3, 'abc'_String :: 2) -> jaroWinklerSimilarity(randomString(_CAST(131072._Float64, 'Float64'_String)), 'abc'_String) Float64 : 1'. (TOO_LARGE_STRING_SIZE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46630) (comment: 02884_string_distance_function.sql) (query 16, line 19) (in query: SELECT jaroWinklerSimilarity(randomString(power(2, 17)), 'abc');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000a8668eb 4. /build/src/Functions/FunctionsStringDistance.cpp:450: DB::ByteJaroWinklerSimilarityImpl::process(char const*, unsigned long, char const*, unsigned long) @ 0x000000000a86e9a1 5. /build/src/Functions/FunctionsStringDistance.cpp:67: DB::FunctionStringDistanceImpl::constantVector(String const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x000000000a86e7d7 6. /build/src/Functions/FunctionsStringDistance.cpp:79: DB::FunctionsStringSimilarity, DB::NameJaroWinklerSimilarity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a86df33 7. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 8. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 11. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:13:20.941294 [ 30862 ] {} TCPHandler: Code: 131. DB::Exception: The string size is too big for function jaroWinklerSimilarity, should be at most 65536: while executing 'FUNCTION jaroWinklerSimilarity(randomString(_CAST(131072._Float64, 'Float64'_String)) :: 3, 'abc'_String :: 2) -> jaroWinklerSimilarity(randomString(_CAST(131072._Float64, 'Float64'_String)), 'abc'_String) Float64 : 1'. (TOO_LARGE_STRING_SIZE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000a8668eb 4. /build/src/Functions/FunctionsStringDistance.cpp:450: DB::ByteJaroWinklerSimilarityImpl::process(char const*, unsigned long, char const*, unsigned long) @ 0x000000000a86e9a1 5. /build/src/Functions/FunctionsStringDistance.cpp:67: DB::FunctionStringDistanceImpl::constantVector(String const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x000000000a86e7d7 6. /build/src/Functions/FunctionsStringDistance.cpp:79: DB::FunctionsStringSimilarity, DB::NameJaroWinklerSimilarity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a86df33 7. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 8. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 11. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:13:20.955676 [ 6619 ] {4b385b39-bc49-4eeb-8367-e78c736a5a42} 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]:54610) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Functions/extractGroups.cpp:70: DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8350d1 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:13:20.965366 [ 6619 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Functions/extractGroups.cpp:70: DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8350d1 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:13:21.245029 [ 6619 ] {7265d0c3-9489-42c8-a2bc-4eca3b184ca2} 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]:54610) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Functions/extractAllGroups.h:103: DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b833c70 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:13:21.269258 [ 6619 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Functions/extractAllGroups.h:103: DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b833c70 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:13:21.354382 [ 31792 ] {d95528cf-16da-4210-86c2-03120bcaa1ff} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date32 for function toSecond: while executing 'FUNCTION toSecond(__table1.x1 :: 1) -> toSecond(__table1.x1) UInt8 : 0'. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46620) (comment: 01921_datatype_date32.sql) (query 22, line 24) (in query: select toSecond(x1) from t1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000009fb18cb 4. /build/src/Functions/DateTimeTransforms.cpp:18: DB::throwDate32IsNotSupported(char const*) @ 0x0000000009fb17a5 5. /build/src/Functions/DateTimeTransforms.h:1569: COW::immutable_ptr DB::DateTimeTransformImpl, DB::ToSecondImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToSecondImpl const&) @ 0x000000000e78eb1e 6. /build/src/Functions/FunctionDateOrDateTimeToSomething.h:74: DB::FunctionDateOrDateTimeToSomething, DB::ToSecondImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e78decd 7. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 8. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 11. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:13:21.446725 [ 31792 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date32 for function toSecond: while executing 'FUNCTION toSecond(__table1.x1 :: 1) -> toSecond(__table1.x1) UInt8 : 0'. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000009fb18cb 4. /build/src/Functions/DateTimeTransforms.cpp:18: DB::throwDate32IsNotSupported(char const*) @ 0x0000000009fb17a5 5. /build/src/Functions/DateTimeTransforms.h:1569: COW::immutable_ptr DB::DateTimeTransformImpl, DB::ToSecondImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToSecondImpl const&) @ 0x000000000e78eb1e 6. /build/src/Functions/FunctionDateOrDateTimeToSomething.h:74: DB::FunctionDateOrDateTimeToSomething, DB::ToSecondImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e78decd 7. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 8. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 11. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:13:21.447432 [ 6619 ] {3f397d0f-5ca3-4d0c-a6f9-9427ca086a20} 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]:54610) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Functions/extractGroups.cpp:70: DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8350d1 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:13:21.459016 [ 6619 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Functions/extractGroups.cpp:70: DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8350d1 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:13:21.528603 [ 6619 ] {c985686f-06c4-4753-a493-51306c6a572c} 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]:54610) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Functions/extractAllGroups.h:103: DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b833c70 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:13:21.546618 [ 6619 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Functions/extractAllGroups.h:103: DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b833c70 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:13:21.771943 [ 6619 ] {a5208314-b8ff-4cb1-b7a1-b14a347e32be} 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]:54610) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Functions/extractGroups.cpp:70: DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8350d1 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:13:21.787832 [ 6619 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Functions/extractGroups.cpp:70: DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8350d1 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:13:21.895845 [ 6619 ] {2d046c15-a38a-4c98-b2bd-c5b10e4a4a5b} 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]:54610) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Functions/extractAllGroups.h:103: DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b833c70 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:13:21.901432 [ 6619 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Functions/extractAllGroups.h:103: DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b833c70 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:13:22.164867 [ 6619 ] {17fd9de3-4e04-47fd-ba38-a0149c7cd580} 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]:54610) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Functions/extractGroups.cpp:75: DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b835157 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:13:22.180383 [ 6619 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Functions/extractGroups.cpp:75: DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b835157 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:13:22.460972 [ 6619 ] {fc8ac26a-dc70-4f8b-aa02-1ef0eb236923} 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]:54610) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Functions/extractAllGroups.h:108: DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b833cf6 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:13:22.548589 [ 6619 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Functions/extractAllGroups.h:108: DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b833cf6 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:13:22.646572 [ 6608 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 77918.137267 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x0000000013ad84ab 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x0000000013ad77ec 5. /build/src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x000000001496af1f 6. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000168d1a5a 7. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0c24 8. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168cfe81 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x00000000168cf907 5. /build/src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000001680710e 6. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 2025.07.13 02:13:25.366783 [ 31788 ] {e6c1bddd-7b4f-407f-9e62-9d2a63cfa5cb} executeQuery: Code: 469. DB::Exception: Constraint `cs_value2` for table test_7.table_for_rename1 (e87d9387-fa51-41a4-b542-f5338a95d669) is violated at row 1. Expression: (toInt64(value2) < toInt64(value3)). Column values: value2 = '1', value3 = '0'. (VIOLATED_CONSTRAINT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54680) (comment: 01277_alter_rename_column_constraint_zookeeper_long.sql) (query 4, line 20) (in query: INSERT INTO table_for_rename1 SELECT toDate('2019-10-01') + number % 3, number, toString(number), toString(number + 1), toString(number) from numbers(9);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&) @ 0x0000000013bf7039 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000016b2113c 5. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 7. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 10. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 11. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 12. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 13. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168cfe81 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:13:25.387000 [ 31788 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `cs_value2` for table test_7.table_for_rename1 (e87d9387-fa51-41a4-b542-f5338a95d669) is violated at row 1. Expression: (toInt64(value2) < toInt64(value3)). Column values: value2 = '1', value3 = '0'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&) @ 0x0000000013bf7039 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000016b2113c 5. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 7. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 10. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 11. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 12. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 13. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168cfe81 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x00000000168cf907 5. /build/src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000001680710e 6. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 2025.07.13 02:13:25.504432 [ 27539 ] {} SettingsSanity: Sanity check: 'max_block_size' value is too high (9223372036854775806). Reduced to 4294967296 2025.07.13 02:13:25.557070 [ 27539 ] {f0da102b-e438-4a7f-a05a-5d2ba387cc9a} SettingsSanity: Sanity check: 'max_block_size' value is too high (9223372036854775806). Reduced to 4294967296 2025.07.13 02:13:25.668214 [ 27539 ] {f0da102b-e438-4a7f-a05a-5d2ba387cc9a} SettingsSanity: Sanity check: 'max_block_size' value is too high (9223372036854775806). Reduced to 4294967296 2025.07.13 02:13:25.788352 [ 16763 ] {ae8a629b-0e5f-42e4-a7ba-f801f2102d1d} executeQuery: Code: 43. DB::Exception: Illegal type String of argument of function toStartOfSecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfSecond('123'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54756) (comment: 01269_toStartOfSecond.sql) (query 1, line 1) (in query: -- Error cases SELECT toStartOfSecond('123');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/IFunctionDateOrDateTime.h:47: DB::FunctionDateOrDateTimeBase::checkArguments(std::vector> const&, bool) const @ 0x000000000e7351d4 5. /build/src/Functions/FunctionDateOrDateTimeToSomething.h:23: DB::FunctionDateOrDateTimeToSomething::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e7d9c51 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:25.797507 [ 16763 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of argument of function toStartOfSecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfSecond('123'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/IFunctionDateOrDateTime.h:47: DB::FunctionDateOrDateTimeBase::checkArguments(std::vector> const&, bool) const @ 0x000000000e7351d4 5. /build/src/Functions/FunctionDateOrDateTimeToSomething.h:23: DB::FunctionDateOrDateTimeToSomething::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e7d9c51 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:25.845226 [ 27539 ] {} SettingsSanity: Sanity check: 'max_block_size' value is too high (9223372036854775806). Reduced to 4294967296 2025.07.13 02:13:25.865169 [ 27539 ] {733b3f36-5f3b-4e84-b0bd-18b381e8b741} SettingsSanity: Sanity check: 'max_block_size' value is too high (9223372036854775806). Reduced to 4294967296 2025.07.13 02:13:25.871945 [ 27539 ] {733b3f36-5f3b-4e84-b0bd-18b381e8b741} SettingsSanity: Sanity check: 'max_block_size' value is too high (9223372036854775806). Reduced to 4294967296 2025.07.13 02:13:26.061795 [ 27539 ] {fc52c371-7b2c-4bac-8856-fdbfb3936282} SettingsSanity: Sanity check: 'max_block_size' value is too high (9223372036854775806). Reduced to 4294967296 2025.07.13 02:13:26.124216 [ 27539 ] {} SettingsSanity: Sanity check: 'max_block_size' value is too high (9223372036854775806). Reduced to 4294967296 2025.07.13 02:13:26.129650 [ 16763 ] {e15f9e44-a4f6-4350-b67a-722a2c7a4339} executeQuery: Code: 43. DB::Exception: Illegal type DateTime of argument for function toStartOfSecond: In scope SELECT toStartOfSecond(now()). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54756) (comment: 01269_toStartOfSecond.sql) (query 2, line 3) (in query: SELECT toStartOfSecond(now());), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000009fd7e2b 4. /build/src/Functions/DateTimeTransforms.h:874: COW::immutable_ptr DB::DateTimeTransformImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToStartOfSecondImpl const&) @ 0x000000000e7da470 5. /build/src/Functions/FunctionDateOrDateTimeToSomething.h:76: DB::FunctionDateOrDateTimeToSomething::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e7d997a 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:13:26.137942 [ 16763 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type DateTime of argument for function toStartOfSecond: In scope SELECT toStartOfSecond(now()). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000009fd7e2b 4. /build/src/Functions/DateTimeTransforms.h:874: COW::immutable_ptr DB::DateTimeTransformImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToStartOfSecondImpl const&) @ 0x000000000e7da470 5. /build/src/Functions/FunctionDateOrDateTimeToSomething.h:76: DB::FunctionDateOrDateTimeToSomething::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e7d997a 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:13:26.381227 [ 16763 ] {6e79a12a-9aff-4951-9bc6-784fcd8cf483} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfSecond doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfSecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54756) (comment: 01269_toStartOfSecond.sql) (query 3, line 4) (in query: SELECT toStartOfSecond();), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000009fb386b 4. /build/src/Functions/IFunctionDateOrDateTime.h:68: DB::FunctionDateOrDateTimeBase::checkArguments(std::vector> const&, bool) const @ 0x000000000e735316 5. /build/src/Functions/FunctionDateOrDateTimeToSomething.h:23: DB::FunctionDateOrDateTimeToSomething::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e7d9c51 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:26.391031 [ 16763 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfSecond doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfSecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000009fb386b 4. /build/src/Functions/IFunctionDateOrDateTime.h:68: DB::FunctionDateOrDateTimeBase::checkArguments(std::vector> const&, bool) const @ 0x000000000e735316 5. /build/src/Functions/FunctionDateOrDateTimeToSomething.h:23: DB::FunctionDateOrDateTimeToSomething::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e7d9c51 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:26.547765 [ 30862 ] {92cf502b-8f36-4701-b338-3a1b558593e4} executeQuery: Code: 36. DB::Exception: Illegal UTF-8 sequence, while processing 'Â': while executing 'FUNCTION stringJaccardIndexUTF8(materialize('hello'_String) :: 3, materialize('Â'_String) :: 1) -> stringJaccardIndexUTF8(materialize('hello'_String), materialize('Â'_String)) Float64 : 2'. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46630) (comment: 02884_string_distance_function.sql) (query 35, line 48) (in query: SELECT stringJaccardIndexUTF8(materialize('hello'), materialize('\xC2\x01'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x000000000a05dc8b 4. /build/src/Functions/FunctionsStringDistance.cpp:141: DB::parseUTF8String(char const*, unsigned long, std::function, std::function) @ 0x000000000a862b51 5. /build/src/Functions/FunctionsStringDistance.cpp:180: DB::ByteJaccardIndexImpl::process(char const*, unsigned long, char const*, unsigned long) @ 0x000000000a86bf17 6. /build/src/Functions/FunctionsStringDistance.cpp:47: DB::FunctionStringDistanceImpl>::vectorVector(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x000000000a86bb2f 7. /build/src/Functions/FunctionsStringSimilarity.h:117: DB::FunctionsStringSimilarity>, DB::NameJaccardIndexUTF8>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a86b3d8 8. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 9. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 13. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 14. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 15. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 16. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 17. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 18. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 19. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 20. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 21. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 23. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:13:26.556084 [ 30862 ] {} TCPHandler: Code: 36. DB::Exception: Illegal UTF-8 sequence, while processing 'Â': while executing 'FUNCTION stringJaccardIndexUTF8(materialize('hello'_String) :: 3, materialize('Â'_String) :: 1) -> stringJaccardIndexUTF8(materialize('hello'_String), materialize('Â'_String)) Float64 : 2'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x000000000a05dc8b 4. /build/src/Functions/FunctionsStringDistance.cpp:141: DB::parseUTF8String(char const*, unsigned long, std::function, std::function) @ 0x000000000a862b51 5. /build/src/Functions/FunctionsStringDistance.cpp:180: DB::ByteJaccardIndexImpl::process(char const*, unsigned long, char const*, unsigned long) @ 0x000000000a86bf17 6. /build/src/Functions/FunctionsStringDistance.cpp:47: DB::FunctionStringDistanceImpl>::vectorVector(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x000000000a86bb2f 7. /build/src/Functions/FunctionsStringSimilarity.h:117: DB::FunctionsStringSimilarity>, DB::NameJaccardIndexUTF8>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a86b3d8 8. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 9. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 13. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 14. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 15. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 16. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 17. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 18. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 19. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 20. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 21. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 23. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:13:26.686414 [ 5998 ] {e2e6dcaf-f3eb-458f-b516-e75834bb2123} 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 SELECT toMonday(toDate(16433), 'Asia/Istanbul'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54694) (comment: 00189_time_zones_long.sql) (query 18, line 36) (in query: SELECT toMonday(toDate(16433), 'Asia/Istanbul');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/IFunctionDateOrDateTime.h:63: DB::FunctionDateOrDateTimeBase::checkArguments(std::vector> const&, bool) const @ 0x000000000e7354f8 5. /build/src/Functions/FunctionDateOrDateTimeToDateOrDate32.h:37: DB::FunctionDateOrDateTimeToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e777d58 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:26.687810 [ 16763 ] {795f7db9-0cb1-4284-8902-a61f2f19c858} executeQuery: Code: 43. DB::Exception: Function toStartOfSecond supports 1 or 2 arguments. The optional 2nd argument must be a constant string with a timezone name: In scope SELECT toStartOfSecond(now64(), 123). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54756) (comment: 01269_toStartOfSecond.sql) (query 4, line 5) (in query: SELECT toStartOfSecond(now64(), 123);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/IFunctionDateOrDateTime.h:58: DB::FunctionDateOrDateTimeBase::checkArguments(std::vector> const&, bool) const @ 0x000000000e735465 5. /build/src/Functions/FunctionDateOrDateTimeToSomething.h:23: DB::FunctionDateOrDateTimeToSomething::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e7d9c51 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:26.700725 [ 5998 ] {} 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 SELECT toMonday(toDate(16433), 'Asia/Istanbul'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/IFunctionDateOrDateTime.h:63: DB::FunctionDateOrDateTimeBase::checkArguments(std::vector> const&, bool) const @ 0x000000000e7354f8 5. /build/src/Functions/FunctionDateOrDateTimeToDateOrDate32.h:37: DB::FunctionDateOrDateTimeToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e777d58 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:26.703218 [ 16763 ] {} TCPHandler: Code: 43. DB::Exception: Function toStartOfSecond supports 1 or 2 arguments. The optional 2nd argument must be a constant string with a timezone name: In scope SELECT toStartOfSecond(now64(), 123). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/IFunctionDateOrDateTime.h:58: DB::FunctionDateOrDateTimeBase::checkArguments(std::vector> const&, bool) const @ 0x000000000e735465 5. /build/src/Functions/FunctionDateOrDateTimeToSomething.h:23: DB::FunctionDateOrDateTimeToSomething::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e7d9c51 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:26.715783 [ 30862 ] {3af29f4a-5bde-4f67-84e3-3e85a1718236} executeQuery: Code: 36. DB::Exception: Illegal UTF-8 sequence, while processing 'Á': while executing 'FUNCTION stringJaccardIndexUTF8(materialize('hello'_String) :: 3, materialize('Á'_String) :: 1) -> stringJaccardIndexUTF8(materialize('hello'_String), materialize('Á'_String)) Float64 : 2'. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46630) (comment: 02884_string_distance_function.sql) (query 36, line 49) (in query: SELECT stringJaccardIndexUTF8(materialize('hello'), materialize('\xC1\x81'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x000000000a05dc8b 4. /build/src/Functions/FunctionsStringDistance.cpp:141: DB::parseUTF8String(char const*, unsigned long, std::function, std::function) @ 0x000000000a862b51 5. /build/src/Functions/FunctionsStringDistance.cpp:180: DB::ByteJaccardIndexImpl::process(char const*, unsigned long, char const*, unsigned long) @ 0x000000000a86bf17 6. /build/src/Functions/FunctionsStringDistance.cpp:47: DB::FunctionStringDistanceImpl>::vectorVector(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x000000000a86bb2f 7. /build/src/Functions/FunctionsStringSimilarity.h:117: DB::FunctionsStringSimilarity>, DB::NameJaccardIndexUTF8>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a86b3d8 8. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 9. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 13. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 14. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 15. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 16. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 17. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 18. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 19. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 20. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 21. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 23. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:13:26.723820 [ 30862 ] {} TCPHandler: Code: 36. DB::Exception: Illegal UTF-8 sequence, while processing 'Á': while executing 'FUNCTION stringJaccardIndexUTF8(materialize('hello'_String) :: 3, materialize('Á'_String) :: 1) -> stringJaccardIndexUTF8(materialize('hello'_String), materialize('Á'_String)) Float64 : 2'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x000000000a05dc8b 4. /build/src/Functions/FunctionsStringDistance.cpp:141: DB::parseUTF8String(char const*, unsigned long, std::function, std::function) @ 0x000000000a862b51 5. /build/src/Functions/FunctionsStringDistance.cpp:180: DB::ByteJaccardIndexImpl::process(char const*, unsigned long, char const*, unsigned long) @ 0x000000000a86bf17 6. /build/src/Functions/FunctionsStringDistance.cpp:47: DB::FunctionStringDistanceImpl>::vectorVector(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x000000000a86bb2f 7. /build/src/Functions/FunctionsStringSimilarity.h:117: DB::FunctionsStringSimilarity>, DB::NameJaccardIndexUTF8>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a86b3d8 8. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 9. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 13. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 14. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 15. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 16. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 17. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 18. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 19. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 20. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 21. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 23. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:13:26.953046 [ 30862 ] {f6ecd767-11d6-4581-b338-584700991fba} executeQuery: Code: 36. DB::Exception: Illegal UTF-8 sequence, while processing 'ð€€A': while executing 'FUNCTION stringJaccardIndexUTF8(materialize('hello'_String) :: 3, materialize('ð€€A'_String) :: 1) -> stringJaccardIndexUTF8(materialize('hello'_String), materialize('ð€€A'_String)) Float64 : 2'. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46630) (comment: 02884_string_distance_function.sql) (query 37, line 50) (in query: SELECT stringJaccardIndexUTF8(materialize('hello'), materialize('\xF0\x80\x80\x41'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x000000000a05dc8b 4. /build/src/Functions/FunctionsStringDistance.cpp:141: DB::parseUTF8String(char const*, unsigned long, std::function, std::function) @ 0x000000000a862b51 5. /build/src/Functions/FunctionsStringDistance.cpp:180: DB::ByteJaccardIndexImpl::process(char const*, unsigned long, char const*, unsigned long) @ 0x000000000a86bf17 6. /build/src/Functions/FunctionsStringDistance.cpp:47: DB::FunctionStringDistanceImpl>::vectorVector(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x000000000a86bb2f 7. /build/src/Functions/FunctionsStringSimilarity.h:117: DB::FunctionsStringSimilarity>, DB::NameJaccardIndexUTF8>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a86b3d8 8. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 9. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 13. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 14. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 15. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 16. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 17. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 18. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 19. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 20. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 21. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 23. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:13:26.997138 [ 30862 ] {} TCPHandler: Code: 36. DB::Exception: Illegal UTF-8 sequence, while processing 'ð€€A': while executing 'FUNCTION stringJaccardIndexUTF8(materialize('hello'_String) :: 3, materialize('ð€€A'_String) :: 1) -> stringJaccardIndexUTF8(materialize('hello'_String), materialize('ð€€A'_String)) Float64 : 2'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x000000000a05dc8b 4. /build/src/Functions/FunctionsStringDistance.cpp:141: DB::parseUTF8String(char const*, unsigned long, std::function, std::function) @ 0x000000000a862b51 5. /build/src/Functions/FunctionsStringDistance.cpp:180: DB::ByteJaccardIndexImpl::process(char const*, unsigned long, char const*, unsigned long) @ 0x000000000a86bf17 6. /build/src/Functions/FunctionsStringDistance.cpp:47: DB::FunctionStringDistanceImpl>::vectorVector(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x000000000a86bb2f 7. /build/src/Functions/FunctionsStringSimilarity.h:117: DB::FunctionsStringSimilarity>, DB::NameJaccardIndexUTF8>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a86b3d8 8. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 9. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 13. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 14. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 15. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 16. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 17. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 18. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 19. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 20. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 21. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 23. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:13:27.178188 [ 30862 ] {f3f531a9-0f33-4055-b6bd-d27d4ee7b5c9} executeQuery: Code: 36. DB::Exception: Illegal UTF-8 sequence, while processing 'À€': while executing 'FUNCTION stringJaccardIndexUTF8(materialize('hello'_String) :: 3, materialize('À€'_String) :: 1) -> stringJaccardIndexUTF8(materialize('hello'_String), materialize('À€'_String)) Float64 : 2'. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46630) (comment: 02884_string_distance_function.sql) (query 38, line 51) (in query: SELECT stringJaccardIndexUTF8(materialize('hello'), materialize('\xC0\x80'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x000000000a05dc8b 4. /build/src/Functions/FunctionsStringDistance.cpp:141: DB::parseUTF8String(char const*, unsigned long, std::function, std::function) @ 0x000000000a862b51 5. /build/src/Functions/FunctionsStringDistance.cpp:180: DB::ByteJaccardIndexImpl::process(char const*, unsigned long, char const*, unsigned long) @ 0x000000000a86bf17 6. /build/src/Functions/FunctionsStringDistance.cpp:47: DB::FunctionStringDistanceImpl>::vectorVector(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x000000000a86bb2f 7. /build/src/Functions/FunctionsStringSimilarity.h:117: DB::FunctionsStringSimilarity>, DB::NameJaccardIndexUTF8>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a86b3d8 8. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 9. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 13. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 14. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 15. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 16. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 17. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 18. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 19. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 20. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 21. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 23. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:13:27.208464 [ 30862 ] {} TCPHandler: Code: 36. DB::Exception: Illegal UTF-8 sequence, while processing 'À€': while executing 'FUNCTION stringJaccardIndexUTF8(materialize('hello'_String) :: 3, materialize('À€'_String) :: 1) -> stringJaccardIndexUTF8(materialize('hello'_String), materialize('À€'_String)) Float64 : 2'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x000000000a05dc8b 4. /build/src/Functions/FunctionsStringDistance.cpp:141: DB::parseUTF8String(char const*, unsigned long, std::function, std::function) @ 0x000000000a862b51 5. /build/src/Functions/FunctionsStringDistance.cpp:180: DB::ByteJaccardIndexImpl::process(char const*, unsigned long, char const*, unsigned long) @ 0x000000000a86bf17 6. /build/src/Functions/FunctionsStringDistance.cpp:47: DB::FunctionStringDistanceImpl>::vectorVector(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x000000000a86bb2f 7. /build/src/Functions/FunctionsStringSimilarity.h:117: DB::FunctionsStringSimilarity>, DB::NameJaccardIndexUTF8>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a86b3d8 8. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 9. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 13. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 14. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 15. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 16. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 17. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 18. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 19. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 20. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 21. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 23. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:13:27.349689 [ 30862 ] {b20b115d-5607-4591-9b1b-ea193996b47a} executeQuery: Code: 36. DB::Exception: Illegal UTF-8 sequence, while processing 'Ø ': while executing 'FUNCTION stringJaccardIndexUTF8(materialize('hello'_String) :: 3, materialize('Ø\0 '_String) :: 1) -> stringJaccardIndexUTF8(materialize('hello'_String), materialize('Ø\0 '_String)) Float64 : 2'. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46630) (comment: 02884_string_distance_function.sql) (query 39, line 52) (in query: SELECT stringJaccardIndexUTF8(materialize('hello'), materialize('\xD8\x00 '));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x000000000a05dc8b 4. /build/src/Functions/FunctionsStringDistance.cpp:141: DB::parseUTF8String(char const*, unsigned long, std::function, std::function) @ 0x000000000a862b51 5. /build/src/Functions/FunctionsStringDistance.cpp:180: DB::ByteJaccardIndexImpl::process(char const*, unsigned long, char const*, unsigned long) @ 0x000000000a86bf17 6. /build/src/Functions/FunctionsStringDistance.cpp:47: DB::FunctionStringDistanceImpl>::vectorVector(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x000000000a86bb2f 7. /build/src/Functions/FunctionsStringSimilarity.h:117: DB::FunctionsStringSimilarity>, DB::NameJaccardIndexUTF8>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a86b3d8 8. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 9. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 13. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 14. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 15. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 16. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 17. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 18. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 19. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 20. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 21. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 23. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:13:27.356104 [ 30862 ] {} TCPHandler: Code: 36. DB::Exception: Illegal UTF-8 sequence, while processing 'Ø ': while executing 'FUNCTION stringJaccardIndexUTF8(materialize('hello'_String) :: 3, materialize('Ø\0 '_String) :: 1) -> stringJaccardIndexUTF8(materialize('hello'_String), materialize('Ø\0 '_String)) Float64 : 2'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x000000000a05dc8b 4. /build/src/Functions/FunctionsStringDistance.cpp:141: DB::parseUTF8String(char const*, unsigned long, std::function, std::function) @ 0x000000000a862b51 5. /build/src/Functions/FunctionsStringDistance.cpp:180: DB::ByteJaccardIndexImpl::process(char const*, unsigned long, char const*, unsigned long) @ 0x000000000a86bf17 6. /build/src/Functions/FunctionsStringDistance.cpp:47: DB::FunctionStringDistanceImpl>::vectorVector(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x000000000a86bb2f 7. /build/src/Functions/FunctionsStringSimilarity.h:117: DB::FunctionsStringSimilarity>, DB::NameJaccardIndexUTF8>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a86b3d8 8. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 9. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 13. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 14. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 15. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 16. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 17. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 18. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 19. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 20. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 21. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 23. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:13:27.546271 [ 30862 ] {670acd4f-3da7-461d-aa44-f05d575cce94} executeQuery: Code: 36. DB::Exception: Illegal UTF-8 sequence, while processing 'Ü': while executing 'FUNCTION stringJaccardIndexUTF8(materialize('hello'_String) :: 3, materialize('Ü\0'_String) :: 1) -> stringJaccardIndexUTF8(materialize('hello'_String), materialize('Ü\0'_String)) Float64 : 2'. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46630) (comment: 02884_string_distance_function.sql) (query 40, line 53) (in query: SELECT stringJaccardIndexUTF8(materialize('hello'), materialize('\xDC\x00'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x000000000a05dc8b 4. /build/src/Functions/FunctionsStringDistance.cpp:141: DB::parseUTF8String(char const*, unsigned long, std::function, std::function) @ 0x000000000a862b51 5. /build/src/Functions/FunctionsStringDistance.cpp:180: DB::ByteJaccardIndexImpl::process(char const*, unsigned long, char const*, unsigned long) @ 0x000000000a86bf17 6. /build/src/Functions/FunctionsStringDistance.cpp:47: DB::FunctionStringDistanceImpl>::vectorVector(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x000000000a86bb2f 7. /build/src/Functions/FunctionsStringSimilarity.h:117: DB::FunctionsStringSimilarity>, DB::NameJaccardIndexUTF8>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a86b3d8 8. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 9. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 13. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 14. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 15. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 16. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 17. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 18. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 19. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 20. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 21. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 23. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:13:27.558152 [ 30862 ] {} TCPHandler: Code: 36. DB::Exception: Illegal UTF-8 sequence, while processing 'Ü': while executing 'FUNCTION stringJaccardIndexUTF8(materialize('hello'_String) :: 3, materialize('Ü\0'_String) :: 1) -> stringJaccardIndexUTF8(materialize('hello'_String), materialize('Ü\0'_String)) Float64 : 2'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x000000000a05dc8b 4. /build/src/Functions/FunctionsStringDistance.cpp:141: DB::parseUTF8String(char const*, unsigned long, std::function, std::function) @ 0x000000000a862b51 5. /build/src/Functions/FunctionsStringDistance.cpp:180: DB::ByteJaccardIndexImpl::process(char const*, unsigned long, char const*, unsigned long) @ 0x000000000a86bf17 6. /build/src/Functions/FunctionsStringDistance.cpp:47: DB::FunctionStringDistanceImpl>::vectorVector(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x000000000a86bb2f 7. /build/src/Functions/FunctionsStringSimilarity.h:117: DB::FunctionsStringSimilarity>, DB::NameJaccardIndexUTF8>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a86b3d8 8. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 9. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 13. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 14. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 15. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 16. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 17. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 18. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 19. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 20. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 21. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 23. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:13:28.151431 [ 5998 ] {00486b9b-7e66-4f6d-b34a-02cf451c9214} executeQuery: Code: 43. DB::Exception: The timezone argument of function toStartOfWeek is allowed only when the 1st argument is DateTime or DateTime64.: In scope SELECT toStartOfWeek(toDate(16433), 0, 'Asia/Istanbul'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54694) (comment: 00189_time_zones_long.sql) (query 26, line 47) (in query: SELECT toStartOfWeek(toDate(16433), 0, 'Asia/Istanbul');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/IFunctionCustomWeek.h:122: DB::IFunctionCustomWeek::checkArguments(std::vector> const&, bool, bool) const @ 0x000000000e749eb4 5. /build/src/Functions/FunctionCustomWeekToDateOrDate32.h:36: DB::FunctionCustomWeekToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e7476d6 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:28.184770 [ 5998 ] {} TCPHandler: Code: 43. DB::Exception: The timezone argument of function toStartOfWeek is allowed only when the 1st argument is DateTime or DateTime64.: In scope SELECT toStartOfWeek(toDate(16433), 0, 'Asia/Istanbul'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/IFunctionCustomWeek.h:122: DB::IFunctionCustomWeek::checkArguments(std::vector> const&, bool, bool) const @ 0x000000000e749eb4 5. /build/src/Functions/FunctionCustomWeekToDateOrDate32.h:36: DB::FunctionCustomWeekToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e7476d6 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:28.222880 [ 3895 ] {} test_7.t_light_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:13:28.224257 [ 4024 ] {} test_7.table_rename_with_ttl (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:13:28.225652 [ 3930 ] {} test_7.test (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:13:28.227471 [ 3684 ] {} test_7.replicated_table_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:13:28.231868 [ 3573 ] {} test_7.table_for_rename1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:13:28.232173 [ 3948 ] {} test_3.fetches_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:13:28.236001 [ 3593 ] {} test_13.projection_broken_parts_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:13:28.243892 [ 3958 ] {} test_1.`03014_async_with_dedup_part_log` (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:13:28.409913 [ 3755 ] {} test_3.fetches_r2 (a4efee30-fbe8-477e-aee0-c140ed11fdeb): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00715_fetch_merged_or_mutated_part_zookeeper_test_3/fetches/replicas/r2), cannot update queue. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:3795: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x0000000015e1b5bd 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013882414 6. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000138854aa 7. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000013885c47 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:28.421882 [ 3843 ] {} test_7.table_for_rename1 (e87d9387-fa51-41a4-b542-f5338a95d669): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_7/test_01277/test_for_rename/replicas/1), cannot update queue. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:3795: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x0000000015e1b5bd 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013882414 6. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000138854aa 7. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000013885c47 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:28.422240 [ 3809 ] {} test_7.table_for_rename1 (e87d9387-fa51-41a4-b542-f5338a95d669): void DB::StorageReplicatedMergeTree::mergeSelectingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/test_7/test_01277/test_for_rename/replicas/1/log_pointer. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000000b9616ab 4. /build/src/Common/ZooKeeper/KeeperException.h:37: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000000b96104b 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:696: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x0000000017063856 6. /build/src/Common/ZooKeeper/ZooKeeper.cpp:664: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x0000000017063536 7. /build/src/Common/ZooKeeper/ZooKeeper.cpp:633: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x0000000017063398 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:640: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x00000000164e5036 9. /build/src/Storages/MergeTree/Compaction/MergePredicates/ReplicatedMergeTreeMergePredicate.cpp:74: DB::ReplicatedMergeTreeZooKeeperMergePredicate::ReplicatedMergeTreeZooKeeperMergePredicate(DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>) @ 0x00000000165995bf 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::ReplicatedMergeTreeZooKeeperMergePredicate* std::construct_at[abi:se190107]&, std::optional, std::equal_to, std::allocator>>, DB::ReplicatedMergeTreeZooKeeperMergePredicate*>(DB::ReplicatedMergeTreeZooKeeperMergePredicate*, DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x0000000016508e5a 11. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::ReplicatedMergeTreeQueue::getMergePredicate(std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x00000000164fb54c 12. /build/src/Storages/StorageReplicatedMergeTree.cpp:4159: DB::StorageReplicatedMergeTree::mergeSelectingTask()::$_0::operator()() const @ 0x0000000015e1f13e 13. /build/src/Storages/StorageReplicatedMergeTree.cpp:4192: DB::StorageReplicatedMergeTree::mergeSelectingTask() @ 0x0000000015e1cc45 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013882414 15. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000138854aa 16. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000013885c47 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 18. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:28.423169 [ 3595 ] {} test_1.`03014_async_with_dedup_part_log` (9a000735-dc34-4879-9e30-baafd35bc614): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/table/test_1/03014_async_with_dedup_part_log/replicas/r1), cannot update queue. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:3795: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x0000000015e1b5bd 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013882414 6. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000138854aa 7. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000013885c47 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:28.427464 [ 3641 ] {} test_7.table_for_rename1 (e87d9387-fa51-41a4-b542-f5338a95d669): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x000000001708ed1b 3. /build/src/Common/ZooKeeper/KeeperException.h:58: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x00000000170c45d3 4. /build/src/Common/ZooKeeper/ZooKeeperImpl.cpp:1557: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x00000000170c7d4a 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:1357: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001705f480 6. /build/src/Common/ZooKeeper/ZooKeeper.cpp:300: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001705efd5 7. /build/src/Common/ZooKeeper/ZooKeeper.cpp:374: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001705fbf2 8. /build/src/Common/ZooKeeper/ZooKeeper.cpp:336: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001705fb0b 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:929: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x00000000164e9406 10. /build/src/Storages/StorageReplicatedMergeTree.cpp:3833: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x0000000015e1b9b8 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013882414 12. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000138854aa 13. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000013885c47 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:28.427619 [ 3585 ] {} test_3.fetches_r2 (a4efee30-fbe8-477e-aee0-c140ed11fdeb): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x000000001708ed1b 3. /build/src/Common/ZooKeeper/KeeperException.h:58: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x00000000170c45d3 4. /build/src/Common/ZooKeeper/ZooKeeperImpl.cpp:1557: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x00000000170c7d4a 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:1357: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001705f480 6. /build/src/Common/ZooKeeper/ZooKeeper.cpp:300: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001705efd5 7. /build/src/Common/ZooKeeper/ZooKeeper.cpp:374: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001705fbf2 8. /build/src/Common/ZooKeeper/ZooKeeper.cpp:336: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001705fb0b 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:929: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x00000000164e9406 10. /build/src/Storages/StorageReplicatedMergeTree.cpp:3833: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x0000000015e1b9b8 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013882414 12. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000138854aa 13. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000013885c47 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:28.440782 [ 3814 ] {} test_m2kyy9ix.wikistat2 (abcdc9c8-22fd-4f0a-ad6c-1958420efc55): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x000000001708ed1b 3. /build/src/Common/ZooKeeper/KeeperException.h:58: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x00000000170c45d3 4. /build/src/Common/ZooKeeper/ZooKeeperImpl.cpp:1557: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x00000000170c7d4a 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:1357: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001705f480 6. /build/src/Common/ZooKeeper/ZooKeeper.cpp:300: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001705efd5 7. /build/src/Common/ZooKeeper/ZooKeeper.cpp:374: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001705fbf2 8. /build/src/Common/ZooKeeper/ZooKeeper.cpp:336: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001705fb0b 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:929: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x00000000164e9406 10. /build/src/Storages/StorageReplicatedMergeTree.cpp:3833: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x0000000015e1b9b8 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013882414 12. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000138854aa 13. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000013885c47 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:28.448487 [ 3859 ] {} test_m2kyy9ix.wikistat1 (a89a7882-5290-4dce-9d96-642db4245bc0): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x000000001708ed1b 3. /build/src/Common/ZooKeeper/KeeperException.h:58: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x00000000170c45d3 4. /build/src/Common/ZooKeeper/ZooKeeperImpl.cpp:1557: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x00000000170c7d4a 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:1357: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001705f480 6. /build/src/Common/ZooKeeper/ZooKeeper.cpp:300: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001705efd5 7. /build/src/Common/ZooKeeper/ZooKeeper.cpp:374: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001705fbf2 8. /build/src/Common/ZooKeeper/ZooKeeper.cpp:336: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001705fb0b 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:929: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x00000000164e9406 10. /build/src/Storages/StorageReplicatedMergeTree.cpp:3833: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x0000000015e1b9b8 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013882414 12. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000138854aa 13. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000013885c47 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:28.409662 [ 4027 ] {} test_1.`03014_async_with_dedup_part_log` (9a000735-dc34-4879-9e30-baafd35bc614): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x000000001708ed1b 3. /build/src/Common/ZooKeeper/KeeperException.h:58: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x00000000170c45d3 4. /build/src/Common/ZooKeeper/ZooKeeperImpl.cpp:1557: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x00000000170c7d4a 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:1357: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001705f480 6. /build/src/Common/ZooKeeper/ZooKeeper.cpp:300: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001705efd5 7. /build/src/Common/ZooKeeper/ZooKeeper.cpp:374: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001705fbf2 8. /build/src/Common/ZooKeeper/ZooKeeper.cpp:336: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001705fb0b 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:929: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x00000000164e9406 10. /build/src/Storages/StorageReplicatedMergeTree.cpp:3833: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x0000000015e1b9b8 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013882414 12. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000138854aa 13. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000013885c47 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:28.554224 [ 31788 ] {113e9dbf-f4b5-4cac-9f05-65971ba78526} executeQuery: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/test_7/test_01277/test_for_rename/replicas/1/queue/queue-0000000007. (KEEPER_EXCEPTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54680) (comment: 01277_alter_rename_column_constraint_zookeeper_long.sql) (query 7, line 25) (in query: ALTER TABLE table_for_rename1 RENAME COLUMN value2 TO value5;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000000b9616ab 4. /build/src/Common/ZooKeeper/KeeperException.h:37: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000000b96104b 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:1065: zkutil::ZooKeeper::waitForDisappear(String const&, std::function const&) @ 0x0000000017067d7a 6. /build/src/Storages/StorageReplicatedMergeTree.cpp:7383: DB::StorageReplicatedMergeTree::tryWaitForReplicaToProcessLogEntry(String const&, String const&, DB::ReplicatedMergeTreeLogEntryData const&, long) @ 0x0000000015e60622 7. /build/src/Storages/StorageReplicatedMergeTree.cpp:7185: DB::StorageReplicatedMergeTree::waitForLogEntryToBeProcessedIfNecessary(DB::ReplicatedMergeTreeLogEntryData const&, std::shared_ptr, String const&) @ 0x0000000015e46222 8. /build/src/Storages/StorageReplicatedMergeTree.cpp:6713: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000015e4c22c 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd065 10. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:13:28.598262 [ 31788 ] {} TCPHandler: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/test_7/test_01277/test_for_rename/replicas/1/queue/queue-0000000007. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000000b9616ab 4. /build/src/Common/ZooKeeper/KeeperException.h:37: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000000b96104b 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:1065: zkutil::ZooKeeper::waitForDisappear(String const&, std::function const&) @ 0x0000000017067d7a 6. /build/src/Storages/StorageReplicatedMergeTree.cpp:7383: DB::StorageReplicatedMergeTree::tryWaitForReplicaToProcessLogEntry(String const&, String const&, DB::ReplicatedMergeTreeLogEntryData const&, long) @ 0x0000000015e60622 7. /build/src/Storages/StorageReplicatedMergeTree.cpp:7185: DB::StorageReplicatedMergeTree::waitForLogEntryToBeProcessedIfNecessary(DB::ReplicatedMergeTreeLogEntryData const&, std::shared_ptr, String const&) @ 0x0000000015e46222 8. /build/src/Storages/StorageReplicatedMergeTree.cpp:6713: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000015e4c22c 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd065 10. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:13:28.732835 [ 4313 ] {} test_7.table_for_rename1 (e87d9387-fa51-41a4-b542-f5338a95d669): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 999. Coordination::Exception: Session expired (fault injected on send). (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x000000001652733b 3. /build/src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000170ca430 4. /build/src/Common/ZooKeeper/ZooKeeperImpl.cpp:1781: Coordination::ZooKeeper::maybeInjectSendFault() @ 0x00000000170c4851 5. /build/src/Common/ZooKeeper/ZooKeeperImpl.cpp:1294: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x00000000170c4459 6. /build/src/Common/ZooKeeper/ZooKeeperImpl.cpp:1643: Coordination::ZooKeeper::multi(std::span const, 18446744073709551615ul>, std::function) @ 0x00000000170c8d9c 7. /build/src/Common/ZooKeeper/ZooKeeper.cpp:1448: zkutil::ZooKeeper::asyncTryMultiNoThrow(std::span const, 18446744073709551615ul>) @ 0x000000001706c3a1 8. /build/src/Common/ZooKeeper/ZooKeeper.cpp:1435: zkutil::ZooKeeper::multiImpl(std::vector, std::allocator>> const&, std::vector, std::allocator>>&, bool) @ 0x0000000017061337 9. /build/src/Common/ZooKeeper/ZooKeeper.cpp:806: zkutil::ZooKeeper::multi(std::vector, std::allocator>> const&, bool) @ 0x000000001706496b 10. /build/src/Storages/StorageReplicatedMergeTree.cpp:6367: DB::StorageReplicatedMergeTree::executeMetadataAlter(DB::ReplicatedMergeTreeLogEntry const&) @ 0x0000000015def9d6 11. /build/src/Storages/StorageReplicatedMergeTree.cpp:2355: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015dda514 12. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015eb81fe 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000164fb1a3 14. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015e1bcca 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000161700b2 16. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001621dad0 17. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001621e3ba 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 22. ? @ 0x00007f7210eb6ac3 23. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:28.939104 [ 5988 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:13:29.315465 [ 31788 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000013779f8b 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000137794b8 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778bc3 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678d325 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:29.458551 [ 31792 ] {dde01688-a784-4973-93c1-2db68ca6ab4a} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date32 for function toStartOfSecond: while executing 'FUNCTION toStartOfSecond(__table1.x1 :: 1) -> toStartOfSecond(__table1.x1) DateTime64(3) : 0'. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46620) (comment: 01921_datatype_date32.sql) (query 46, line 48) (in query: select toStartOfSecond(x1) from t1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000009fb18cb 4. /build/src/Functions/DateTimeTransforms.cpp:18: DB::throwDate32IsNotSupported(char const*) @ 0x0000000009fb17a5 5. /build/src/Functions/DateTimeTransforms.h:878: COW::immutable_ptr DB::DateTimeTransformImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToStartOfSecondImpl const&) @ 0x000000000e7da139 6. /build/src/Functions/FunctionDateOrDateTimeToSomething.h:74: DB::FunctionDateOrDateTimeToSomething::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e7d994d 7. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 8. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 11. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:13:29.490004 [ 31792 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date32 for function toStartOfSecond: while executing 'FUNCTION toStartOfSecond(__table1.x1 :: 1) -> toStartOfSecond(__table1.x1) DateTime64(3) : 0'. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000009fb18cb 4. /build/src/Functions/DateTimeTransforms.cpp:18: DB::throwDate32IsNotSupported(char const*) @ 0x0000000009fb17a5 5. /build/src/Functions/DateTimeTransforms.h:878: COW::immutable_ptr DB::DateTimeTransformImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToStartOfSecondImpl const&) @ 0x000000000e7da139 6. /build/src/Functions/FunctionDateOrDateTimeToSomething.h:74: DB::FunctionDateOrDateTimeToSomething::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e7d994d 7. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 8. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 11. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:13:30.212355 [ 5998 ] {af7c2fcc-1bd0-4c22-b5be-59de2c8a6a4f} executeQuery: Code: 43. DB::Exception: The timezone argument of function toStartOfWeek is allowed only when the 1st argument is DateTime or DateTime64.: In scope SELECT toStartOfWeek(toDate(16433), 1, 'Asia/Istanbul'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54694) (comment: 00189_time_zones_long.sql) (query 34, line 58) (in query: SELECT toStartOfWeek(toDate(16433), 1, 'Asia/Istanbul');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/IFunctionCustomWeek.h:122: DB::IFunctionCustomWeek::checkArguments(std::vector> const&, bool, bool) const @ 0x000000000e749eb4 5. /build/src/Functions/FunctionCustomWeekToDateOrDate32.h:36: DB::FunctionCustomWeekToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e7476d6 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:30.231610 [ 5998 ] {} TCPHandler: Code: 43. DB::Exception: The timezone argument of function toStartOfWeek is allowed only when the 1st argument is DateTime or DateTime64.: In scope SELECT toStartOfWeek(toDate(16433), 1, 'Asia/Istanbul'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/IFunctionCustomWeek.h:122: DB::IFunctionCustomWeek::checkArguments(std::vector> const&, bool, bool) const @ 0x000000000e749eb4 5. /build/src/Functions/FunctionCustomWeekToDateOrDate32.h:36: DB::FunctionCustomWeekToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e7476d6 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:30.327050 [ 31792 ] {30341f3c-c890-4b47-b399-e491c0879bf5} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date32 for function toStartOfMinute: while executing 'FUNCTION toStartOfMinute(__table1.x1 :: 1) -> toStartOfMinute(__table1.x1) DateTime : 0'. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46620) (comment: 01921_datatype_date32.sql) (query 48, line 50) (in query: select toStartOfMinute(x1) from t1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000009fb18cb 4. /build/src/Functions/DateTimeTransforms.cpp:18: DB::throwDate32IsNotSupported(char const*) @ 0x0000000009fb17a5 5. /build/src/Functions/DateTimeTransforms.h:831: COW::immutable_ptr DB::DateTimeTransformImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToStartOfMinuteImpl const&) @ 0x000000000e7d3659 6. /build/src/Functions/FunctionDateOrDateTimeToDateTimeOrDateTime64.h:77: DB::FunctionDateOrDateTimeToDateTimeOrDateTime64::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e7d2b1e 7. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 8. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 11. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:13:30.354059 [ 31792 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date32 for function toStartOfMinute: while executing 'FUNCTION toStartOfMinute(__table1.x1 :: 1) -> toStartOfMinute(__table1.x1) DateTime : 0'. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000009fb18cb 4. /build/src/Functions/DateTimeTransforms.cpp:18: DB::throwDate32IsNotSupported(char const*) @ 0x0000000009fb17a5 5. /build/src/Functions/DateTimeTransforms.h:831: COW::immutable_ptr DB::DateTimeTransformImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToStartOfMinuteImpl const&) @ 0x000000000e7d3659 6. /build/src/Functions/FunctionDateOrDateTimeToDateTimeOrDateTime64.h:77: DB::FunctionDateOrDateTimeToDateTimeOrDateTime64::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e7d2b1e 7. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 8. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 11. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:13:30.811915 [ 31792 ] {09620ec2-0ff7-4dda-a20f-1df88a7b93c3} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date32 for function toStartOfFiveMinutes: while executing 'FUNCTION toStartOfFiveMinutes(__table1.x1 :: 1) -> toStartOfFiveMinutes(__table1.x1) DateTime : 0'. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46620) (comment: 01921_datatype_date32.sql) (query 50, line 52) (in query: select toStartOfFiveMinutes(x1) from t1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000009fb18cb 4. /build/src/Functions/DateTimeTransforms.cpp:18: DB::throwDate32IsNotSupported(char const*) @ 0x0000000009fb17a5 5. /build/src/Functions/DateTimeTransforms.h:1029: COW::immutable_ptr DB::DateTimeTransformImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToStartOfFiveMinutesImpl const&) @ 0x000000000e795219 6. /build/src/Functions/FunctionDateOrDateTimeToDateTimeOrDateTime64.h:77: DB::FunctionDateOrDateTimeToDateTimeOrDateTime64::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e7946de 7. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 8. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 11. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:13:30.858572 [ 31792 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date32 for function toStartOfFiveMinutes: while executing 'FUNCTION toStartOfFiveMinutes(__table1.x1 :: 1) -> toStartOfFiveMinutes(__table1.x1) DateTime : 0'. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000009fb18cb 4. /build/src/Functions/DateTimeTransforms.cpp:18: DB::throwDate32IsNotSupported(char const*) @ 0x0000000009fb17a5 5. /build/src/Functions/DateTimeTransforms.h:1029: COW::immutable_ptr DB::DateTimeTransformImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToStartOfFiveMinutesImpl const&) @ 0x000000000e795219 6. /build/src/Functions/FunctionDateOrDateTimeToDateTimeOrDateTime64.h:77: DB::FunctionDateOrDateTimeToDateTimeOrDateTime64::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e7946de 7. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 8. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 11. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:13:31.567554 [ 31792 ] {55e70762-f7ef-4344-96dc-5ce5df89308b} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date32 for function toStartOfTenMinutes: while executing 'FUNCTION toStartOfTenMinutes(__table1.x1 :: 1) -> toStartOfTenMinutes(__table1.x1) DateTime : 0'. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46620) (comment: 01921_datatype_date32.sql) (query 52, line 54) (in query: select toStartOfTenMinutes(x1) from t1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000009fb18cb 4. /build/src/Functions/DateTimeTransforms.cpp:18: DB::throwDate32IsNotSupported(char const*) @ 0x0000000009fb17a5 5. /build/src/Functions/DateTimeTransforms.h:1061: COW::immutable_ptr DB::DateTimeTransformImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToStartOfTenMinutesImpl const&) @ 0x000000000e7e0819 6. /build/src/Functions/FunctionDateOrDateTimeToDateTimeOrDateTime64.h:77: DB::FunctionDateOrDateTimeToDateTimeOrDateTime64::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e7dfcde 7. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 8. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 11. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:13:31.600397 [ 31792 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date32 for function toStartOfTenMinutes: while executing 'FUNCTION toStartOfTenMinutes(__table1.x1 :: 1) -> toStartOfTenMinutes(__table1.x1) DateTime : 0'. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000009fb18cb 4. /build/src/Functions/DateTimeTransforms.cpp:18: DB::throwDate32IsNotSupported(char const*) @ 0x0000000009fb17a5 5. /build/src/Functions/DateTimeTransforms.h:1061: COW::immutable_ptr DB::DateTimeTransformImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToStartOfTenMinutesImpl const&) @ 0x000000000e7e0819 6. /build/src/Functions/FunctionDateOrDateTimeToDateTimeOrDateTime64.h:77: DB::FunctionDateOrDateTimeToDateTimeOrDateTime64::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e7dfcde 7. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 8. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 11. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:13:32.214586 [ 31792 ] {1f59a949-8d1f-461c-a9e5-f0c3626c5490} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date32 for function toStartOfFifteenMinutes: while executing 'FUNCTION toStartOfFifteenMinutes(__table1.x1 :: 1) -> toStartOfFifteenMinutes(__table1.x1) DateTime : 0'. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46620) (comment: 01921_datatype_date32.sql) (query 54, line 56) (in query: select toStartOfFifteenMinutes(x1) from t1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000009fb18cb 4. /build/src/Functions/DateTimeTransforms.cpp:18: DB::throwDate32IsNotSupported(char const*) @ 0x0000000009fb17a5 5. /build/src/Functions/DateTimeTransforms.h:1093: COW::immutable_ptr DB::DateTimeTransformImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToStartOfFifteenMinutesImpl const&) @ 0x000000000e792e79 6. /build/src/Functions/FunctionDateOrDateTimeToDateTimeOrDateTime64.h:77: DB::FunctionDateOrDateTimeToDateTimeOrDateTime64::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e79233e 7. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 8. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 11. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:13:32.239877 [ 31792 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date32 for function toStartOfFifteenMinutes: while executing 'FUNCTION toStartOfFifteenMinutes(__table1.x1 :: 1) -> toStartOfFifteenMinutes(__table1.x1) DateTime : 0'. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000009fb18cb 4. /build/src/Functions/DateTimeTransforms.cpp:18: DB::throwDate32IsNotSupported(char const*) @ 0x0000000009fb17a5 5. /build/src/Functions/DateTimeTransforms.h:1093: COW::immutable_ptr DB::DateTimeTransformImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToStartOfFifteenMinutesImpl const&) @ 0x000000000e792e79 6. /build/src/Functions/FunctionDateOrDateTimeToDateTimeOrDateTime64.h:77: DB::FunctionDateOrDateTimeToDateTimeOrDateTime64::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e79233e 7. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 8. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 11. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:13:32.401480 [ 5998 ] {af7bf9e7-803a-4ade-9e31-45195ab6c319} executeQuery: Code: 43. DB::Exception: The timezone argument of function toLastDayOfWeek is allowed only when the 1st argument is DateTime or DateTime64.: In scope SELECT toLastDayOfWeek(toDate(16433), 0, 'Asia/Istanbul'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54694) (comment: 00189_time_zones_long.sql) (query 42, line 69) (in query: SELECT toLastDayOfWeek(toDate(16433), 0, 'Asia/Istanbul');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/IFunctionCustomWeek.h:122: DB::IFunctionCustomWeek::checkArguments(std::vector> const&, bool, bool) const @ 0x000000000e74d234 5. /build/src/Functions/FunctionCustomWeekToDateOrDate32.h:36: DB::FunctionCustomWeekToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e74aa76 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:32.422280 [ 5998 ] {} TCPHandler: Code: 43. DB::Exception: The timezone argument of function toLastDayOfWeek is allowed only when the 1st argument is DateTime or DateTime64.: In scope SELECT toLastDayOfWeek(toDate(16433), 0, 'Asia/Istanbul'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/IFunctionCustomWeek.h:122: DB::IFunctionCustomWeek::checkArguments(std::vector> const&, bool, bool) const @ 0x000000000e74d234 5. /build/src/Functions/FunctionCustomWeekToDateOrDate32.h:36: DB::FunctionCustomWeekToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e74aa76 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:32.875594 [ 31792 ] {e46b9984-2844-4c2e-80e2-971a81ac8ae1} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date32 for function toStartOfHour: while executing 'FUNCTION toStartOfHour(__table1.x1 :: 1) -> toStartOfHour(__table1.x1) DateTime : 0'. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46620) (comment: 01921_datatype_date32.sql) (query 56, line 58) (in query: select toStartOfHour(x1) from t1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000009fb18cb 4. /build/src/Functions/DateTimeTransforms.cpp:18: DB::throwDate32IsNotSupported(char const*) @ 0x0000000009fb17a5 5. /build/src/Functions/DateTimeTransforms.h:1167: COW::immutable_ptr DB::DateTimeTransformImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToStartOfHourImpl const&) @ 0x000000000e7974d9 6. /build/src/Functions/FunctionDateOrDateTimeToDateTimeOrDateTime64.h:77: DB::FunctionDateOrDateTimeToDateTimeOrDateTime64::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e79699e 7. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 8. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 11. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:13:32.898873 [ 31792 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date32 for function toStartOfHour: while executing 'FUNCTION toStartOfHour(__table1.x1 :: 1) -> toStartOfHour(__table1.x1) DateTime : 0'. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000009fb18cb 4. /build/src/Functions/DateTimeTransforms.cpp:18: DB::throwDate32IsNotSupported(char const*) @ 0x0000000009fb17a5 5. /build/src/Functions/DateTimeTransforms.h:1167: COW::immutable_ptr DB::DateTimeTransformImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToStartOfHourImpl const&) @ 0x000000000e7974d9 6. /build/src/Functions/FunctionDateOrDateTimeToDateTimeOrDateTime64.h:77: DB::FunctionDateOrDateTimeToDateTimeOrDateTime64::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e79699e 7. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 8. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 11. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:13:33.016161 [ 27539 ] {0900014d-f870-4fb6-8f0f-d99af4ec5510} executeQuery: Code: 70. DB::Exception: Field value -1 is out of range of unsigned long type. (CANNOT_CONVERT_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36122) (comment: 02992_settings_overflow.sql) (query 1, line 1) (in query: SET max_threads = -1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Field const&, String&&) @ 0x0000000013ab34ab 4. /build/src/Core/SettingsFields.cpp:75: unsigned long DB::(anonymous namespace)::fieldToNumber(DB::Field const&) @ 0x0000000013aabcd2 5. /build/src/Core/SettingsFields.cpp:231: DB::SettingFieldMaxThreads::SettingFieldMaxThreads(DB::Field const&) @ 0x0000000013aae244 6. /build/src/Core/Settings.cpp:6242: DB::SettingsTraits::Accessor::instance()::$_0::operator()() const::'lambda33'(DB::Field const&)::__invoke(DB::Field const&) @ 0x000000001397dcd2 7. /build/src/Core/Settings.cpp:6241: DB::BaseSettings::castValueUtil(std::basic_string_view>, DB::Field const&) @ 0x0000000013a2afe2 8. /build/src/Core/Settings.cpp:6684: DB::Settings::castValueUtil(std::basic_string_view>, DB::Field const&) @ 0x000000001397b769 9. /build/src/Access/SettingsConstraints.cpp:245: bool DB::getNewValueToCheck(DB::Settings const&, DB::SettingChange&, DB::Field&, bool) @ 0x0000000013779b4b 10. /build/src/Access/SettingsConstraints.cpp:297: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377891b 11. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 12. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 13. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 14. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 15. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 16. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 17. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 22. ? @ 0x00007f7210eb6ac3 23. ? @ 0x00007f7210f48850 2025.07.13 02:13:33.026357 [ 27539 ] {} TCPHandler: Code: 70. DB::Exception: Field value -1 is out of range of unsigned long type. (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Field const&, String&&) @ 0x0000000013ab34ab 4. /build/src/Core/SettingsFields.cpp:75: unsigned long DB::(anonymous namespace)::fieldToNumber(DB::Field const&) @ 0x0000000013aabcd2 5. /build/src/Core/SettingsFields.cpp:231: DB::SettingFieldMaxThreads::SettingFieldMaxThreads(DB::Field const&) @ 0x0000000013aae244 6. /build/src/Core/Settings.cpp:6242: DB::SettingsTraits::Accessor::instance()::$_0::operator()() const::'lambda33'(DB::Field const&)::__invoke(DB::Field const&) @ 0x000000001397dcd2 7. /build/src/Core/Settings.cpp:6241: DB::BaseSettings::castValueUtil(std::basic_string_view>, DB::Field const&) @ 0x0000000013a2afe2 8. /build/src/Core/Settings.cpp:6684: DB::Settings::castValueUtil(std::basic_string_view>, DB::Field const&) @ 0x000000001397b769 9. /build/src/Access/SettingsConstraints.cpp:245: bool DB::getNewValueToCheck(DB::Settings const&, DB::SettingChange&, DB::Field&, bool) @ 0x0000000013779b4b 10. /build/src/Access/SettingsConstraints.cpp:297: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377891b 11. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 12. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 13. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 14. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 15. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 16. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 17. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 22. ? @ 0x00007f7210eb6ac3 23. ? @ 0x00007f7210f48850 2025.07.13 02:13:33.772496 [ 30811 ] {0336bece-2c6a-497a-9637-745b0adbbcf9} 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]:36128) (comment: 03253_getMaxTableNameLength.sql) (query 3, line 3) (in query: SELECT getMaxTableNameLengthForDatabase('');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/getMaxTableNameLength.cpp:76: DB::FunctionGetMaxTableNameLengthForDatabase::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b97432f 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:13:33.808921 [ 30811 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/getMaxTableNameLength.cpp:76: DB::FunctionGetMaxTableNameLengthForDatabase::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b97432f 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:13:33.898325 [ 11482 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:13:34.242894 [ 5998 ] {468666df-f7bd-494b-9677-4b735d802594} executeQuery: Code: 43. DB::Exception: The timezone argument of function toLastDayOfWeek is allowed only when the 1st argument is DateTime or DateTime64.: In scope SELECT toLastDayOfWeek(toDate(16433), 1, 'Asia/Istanbul'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54694) (comment: 00189_time_zones_long.sql) (query 50, line 80) (in query: SELECT toLastDayOfWeek(toDate(16433), 1, 'Asia/Istanbul');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/IFunctionCustomWeek.h:122: DB::IFunctionCustomWeek::checkArguments(std::vector> const&, bool, bool) const @ 0x000000000e74d234 5. /build/src/Functions/FunctionCustomWeekToDateOrDate32.h:36: DB::FunctionCustomWeekToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e74aa76 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:34.292495 [ 5998 ] {} TCPHandler: Code: 43. DB::Exception: The timezone argument of function toLastDayOfWeek is allowed only when the 1st argument is DateTime or DateTime64.: In scope SELECT toLastDayOfWeek(toDate(16433), 1, 'Asia/Istanbul'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/IFunctionCustomWeek.h:122: DB::IFunctionCustomWeek::checkArguments(std::vector> const&, bool, bool) const @ 0x000000000e74d234 5. /build/src/Functions/FunctionCustomWeekToDateOrDate32.h:36: DB::FunctionCustomWeekToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e74aa76 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:34.429978 [ 31788 ] {4c88f337-7bad-478c-a4d3-f7cceb06fdfb} 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]:36050) (comment: 02001_join_on_const.sql) (query 9, line 13) (in query: SELECT count() == 2222 FROM t1 JOIN t2 ON 1 = 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Planner/PlannerJoins.cpp:1253: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x00000000148e4966 5. /build/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&) @ 0x00000000148bf49b 6. /build/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&) @ 0x00000000148bd384 7. /build/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&) @ 0x00000000148adbec 8. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 9. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:13:34.468060 [ 31788 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Planner/PlannerJoins.cpp:1253: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x00000000148e4966 5. /build/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&) @ 0x00000000148bf49b 6. /build/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&) @ 0x00000000148bd384 7. /build/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&) @ 0x00000000148adbec 8. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 9. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:13:35.492709 [ 4922 ] {afacd747-c7c5-4547-be34-42340ceb522a} executeQuery: Code: 264. DB::Exception: Table test_p7eu3l3g.join (170c7269-78e3-477b-9948-777ecffbe1eb) needs the same join_use_nulls setting as present in LEFT or FULL JOIN. (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35954) (comment: 00475_in_join_db_table.sql) (query 17, line 21) (in query: SELECT k, x FROM (SELECT arrayJoin([1, 2]) AS k) js1 ANY LEFT JOIN join USING k ORDER BY ALL;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/StorageJoin.cpp:248: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x0000000015ce357c 5. /build/src/Planner/PlannerJoins.cpp:1244: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x00000000148e410e 6. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0e7d2 7. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 8. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 9. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 14. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 15. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 20. ? @ 0x00007f7210eb6ac3 21. ? @ 0x00007f7210f48850 2025.07.13 02:13:35.539774 [ 4922 ] {} TCPHandler: Code: 264. DB::Exception: Table test_p7eu3l3g.join (170c7269-78e3-477b-9948-777ecffbe1eb) needs the same join_use_nulls setting as present in LEFT or FULL JOIN. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/StorageJoin.cpp:248: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x0000000015ce357c 5. /build/src/Planner/PlannerJoins.cpp:1244: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x00000000148e410e 6. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0e7d2 7. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 8. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 9. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 14. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 15. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 20. ? @ 0x00007f7210eb6ac3 21. ? @ 0x00007f7210f48850 2025.07.13 02:13:35.820353 [ 6612 ] {ce8b56f2-ae47-451b-8162-24118fc0faf7} 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]:52234) (comment: 00475_in_join_db_table.sql) (in query: DROP DATABASE IF EXISTS test_p7eu3l3g SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:13:35.834956 [ 6612 ] {ce8b56f2-ae47-451b-8162-24118fc0faf7} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:36.586966 [ 5998 ] {9ed17056-17bf-41c2-846e-467994ac580c} 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 SELECT toStartOfMonth(toDate(16433), 'Asia/Istanbul'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54694) (comment: 00189_time_zones_long.sql) (query 58, line 91) (in query: SELECT toStartOfMonth(toDate(16433), 'Asia/Istanbul');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/IFunctionDateOrDateTime.h:63: DB::FunctionDateOrDateTimeBase::checkArguments(std::vector> const&, bool) const @ 0x000000000e7354f8 5. /build/src/Functions/FunctionDateOrDateTimeToDateOrDate32.h:37: DB::FunctionDateOrDateTimeToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e7d4fd8 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:36.616975 [ 5998 ] {} 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 SELECT toStartOfMonth(toDate(16433), 'Asia/Istanbul'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/IFunctionDateOrDateTime.h:63: DB::FunctionDateOrDateTimeBase::checkArguments(std::vector> const&, bool) const @ 0x000000000e7354f8 5. /build/src/Functions/FunctionDateOrDateTimeToDateOrDate32.h:37: DB::FunctionDateOrDateTimeToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e7d4fd8 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:36.895388 [ 30811 ] {f9bfb0cb-556d-488e-a7db-de21d79779ea} executeQuery: Code: 46. DB::Exception: Table function 'mysql' cannot be used as an expression. (UNKNOWN_FUNCTION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36174) (comment: 02680_mysql_ast_logical_err.sql) (query 2, line 3) (in query: SELECT count() FROM mysql(mysql('127.0.0.1:9004', currentDatabase(), 'foo', 'default', '[HIDDEN]'), '127.0.0.1:9004', currentDatabase(), 'foo', '[HIDDEN]', '', SETTINGS connect_timeout = 100, connection_wait_timeout = 100, read_write_timeout = 300)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Parsers/ASTFunction.cpp:39: DB::ASTFunction::appendColumnNameImpl(DB::WriteBuffer&) const @ 0x00000000178ce7a4 5. /build/src/Parsers/IAST.cpp:255: DB::IAST::getColumnName() const @ 0x0000000017958b17 6. /build/src/Interpreters/evaluateConstantExpression.cpp:105: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x0000000014b85a5b 7. /build/src/Interpreters/evaluateConstantExpression.cpp:196: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014b87bb9 8. /build/src/Interpreters/evaluateConstantExpression.cpp:207: DB::evaluateConstantExpressionAsLiteral(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014b87d42 9. /build/src/Interpreters/evaluateConstantExpression.cpp:215: DB::evaluateConstantExpressionOrIdentifierAsLiteral(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014b87e2a 10. /build/src/Storages/StorageMySQL.cpp:334: DB::StorageMySQL::getConfiguration(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, DB::MySQLSettings&) @ 0x0000000015d8d964 11. /build/src/TableFunctions/TableFunctionMySQL.cpp:95: DB::(anonymous namespace)::TableFunctionMySQL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000001174fa36 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3bbcc 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:13:36.921545 [ 30811 ] {} TCPHandler: Code: 46. DB::Exception: Table function 'mysql' cannot be used as an expression. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Parsers/ASTFunction.cpp:39: DB::ASTFunction::appendColumnNameImpl(DB::WriteBuffer&) const @ 0x00000000178ce7a4 5. /build/src/Parsers/IAST.cpp:255: DB::IAST::getColumnName() const @ 0x0000000017958b17 6. /build/src/Interpreters/evaluateConstantExpression.cpp:105: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x0000000014b85a5b 7. /build/src/Interpreters/evaluateConstantExpression.cpp:196: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014b87bb9 8. /build/src/Interpreters/evaluateConstantExpression.cpp:207: DB::evaluateConstantExpressionAsLiteral(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014b87d42 9. /build/src/Interpreters/evaluateConstantExpression.cpp:215: DB::evaluateConstantExpressionOrIdentifierAsLiteral(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014b87e2a 10. /build/src/Storages/StorageMySQL.cpp:334: DB::StorageMySQL::getConfiguration(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, DB::MySQLSettings&) @ 0x0000000015d8d964 11. /build/src/TableFunctions/TableFunctionMySQL.cpp:95: DB::(anonymous namespace)::TableFunctionMySQL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000001174fa36 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3bbcc 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:13:37.401496 [ 30811 ] {b98795d2-d856-4d0f-8974-e175dec5f861} executeQuery: Code: 1. DB::Exception: Invalid expression. Expected identifier, literal, matcher, function, subquery. Actual connection_pool_size = 1. (UNSUPPORTED_METHOD) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36174) (comment: 02680_mysql_ast_logical_err.sql) (query 3, line 7) (in query: SELECT count() FROM mysql(mysql('127.0.0.1:9004', currentDatabase(), 'foo', 'default', '[HIDDEN]', SETTINGS connection_pool_size = 1), '127.0.0.1:9004', currentDatabase(), 'foo', '[HIDDEN]', '', SETTINGS connect_timeout = 100, connection_wait_timeout = 100, read_write_timeout = 300)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Analyzer/QueryTreeBuilder.cpp:784: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013f0cab7 5. /build/src/Analyzer/QueryTreeBuilder.cpp:701: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013f0c1f0 6. /build/src/Analyzer/QueryTreeBuilder.cpp:931: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013f0e8d2 7. /build/src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013f0a8b1 8. /build/src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013f0d01d 9. /build/src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013f0a7bd 10. /build/src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x0000000013f0a42b 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014892440 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:13:37.442636 [ 30811 ] {} TCPHandler: Code: 1. DB::Exception: Invalid expression. Expected identifier, literal, matcher, function, subquery. Actual connection_pool_size = 1. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Analyzer/QueryTreeBuilder.cpp:784: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013f0cab7 5. /build/src/Analyzer/QueryTreeBuilder.cpp:701: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013f0c1f0 6. /build/src/Analyzer/QueryTreeBuilder.cpp:931: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013f0e8d2 7. /build/src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013f0a8b1 8. /build/src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013f0d01d 9. /build/src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013f0a7bd 10. /build/src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x0000000013f0a42b 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014892440 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:13:38.003333 [ 31799 ] {bc669610-3601-4c93-8865-79796278d622} executeQuery: Code: 442. DB::Exception: Temporary tables cannot be inside a database. You should not specify a database for a temporary table. (BAD_DATABASE_FOR_TEMPORARY_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36296) (comment: 00841_temporary_table_database.sql) (query 4, line 5) (in query: CREATE TEMPORARY TABLE test.t2_00841 (x UInt8);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1510: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818375 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:13:38.050354 [ 31799 ] {} TCPHandler: Code: 442. DB::Exception: Temporary tables cannot be inside a database. You should not specify a database for a temporary table. (BAD_DATABASE_FOR_TEMPORARY_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1510: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818375 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:13:38.945166 [ 5998 ] {785c7e8b-c604-4956-a95d-5bd8bfeb9182} 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 SELECT toStartOfQuarter(toDate(16343), 'Asia/Istanbul'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54694) (comment: 00189_time_zones_long.sql) (query 66, line 102) (in query: SELECT toStartOfQuarter(toDate(16343), 'Asia/Istanbul');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/IFunctionDateOrDateTime.h:63: DB::FunctionDateOrDateTimeBase::checkArguments(std::vector> const&, bool) const @ 0x000000000e7354f8 5. /build/src/Functions/FunctionDateOrDateTimeToDateOrDate32.h:37: DB::FunctionDateOrDateTimeToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e7d7538 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:38.952722 [ 5998 ] {} 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 SELECT toStartOfQuarter(toDate(16343), 'Asia/Istanbul'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/IFunctionDateOrDateTime.h:63: DB::FunctionDateOrDateTimeBase::checkArguments(std::vector> const&, bool) const @ 0x000000000e7354f8 5. /build/src/Functions/FunctionDateOrDateTimeToDateOrDate32.h:37: DB::FunctionDateOrDateTimeToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e7d7538 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:38.983296 [ 4626 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:13:39.430352 [ 31792 ] {766097f0-8caf-4fa7-9dd9-43b79c40d744} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date32 for function toTime: while executing 'FUNCTION toTime(__table1.x1 :: 1) -> toTime(__table1.x1) DateTime : 0'. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46620) (comment: 01921_datatype_date32.sql) (query 76, line 78) (in query: select toTime(x1) from t1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000009fb18cb 4. /build/src/Functions/DateTimeTransforms.cpp:18: DB::throwDate32IsNotSupported(char const*) @ 0x0000000009fb17a5 5. /build/src/Functions/DateTimeTransforms.h:806: COW::immutable_ptr DB::DateTimeTransformImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToTimeImpl const&) @ 0x000000000e7e5019 6. /build/src/Functions/FunctionDateOrDateTimeToSomething.h:74: DB::FunctionDateOrDateTimeToSomething::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e7e444d 7. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 8. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 11. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:13:39.453785 [ 31792 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date32 for function toTime: while executing 'FUNCTION toTime(__table1.x1 :: 1) -> toTime(__table1.x1) DateTime : 0'. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000009fb18cb 4. /build/src/Functions/DateTimeTransforms.cpp:18: DB::throwDate32IsNotSupported(char const*) @ 0x0000000009fb17a5 5. /build/src/Functions/DateTimeTransforms.h:806: COW::immutable_ptr DB::DateTimeTransformImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToTimeImpl const&) @ 0x000000000e7e5019 6. /build/src/Functions/FunctionDateOrDateTimeToSomething.h:74: DB::FunctionDateOrDateTimeToSomething::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e7e444d 7. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 8. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 11. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:13:40.067720 [ 5095 ] {4f818c3c-8a3c-4adc-9d84-efd420c7e765} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_5o85qiql.t_async_insert_params (id) FORMAT Values' with query id 3a036110-3cb5-4cd1-8e19-45694058b2de. 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:13:40.223434 [ 30860 ] {3a036110-3cb5-4cd1-8e19-45694058b2de} 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]:36386) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::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&&) @ 0x0000000014b93239 4. /build/src/Interpreters/ReplaceQueryParameterVisitor.cpp:105: DB::ReplaceQueryParameterVisitor::visitQueryParameter(std::shared_ptr&) @ 0x0000000014b92998 5. /build/src/Interpreters/evaluateConstantExpression.cpp:97: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x0000000014b85a02 6. /build/src/Interpreters/evaluateConstantExpression.cpp:196: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014b87bb9 7. /build/src/Processors/Formats/Impl/ValuesBlockInputFormat.cpp:548: DB::ValuesBlockInputFormat::parseExpression(DB::IColumn&, unsigned long) @ 0x0000000016af1df7 8. /build/src/Processors/Formats/Impl/ValuesBlockInputFormat.cpp:329: DB::ValuesBlockInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, unsigned long) @ 0x0000000016af0276 9. /build/src/Processors/Formats/Impl/ValuesBlockInputFormat.cpp:129: DB::ValuesBlockInputFormat::read() @ 0x0000000016aef3ee 10. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 11. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 12. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 13. /build/src/Processors/Executors/StreamingFormatExecutor.cpp:77: DB::StreamingFormatExecutor::execute() @ 0x00000000168e4b6a 14. /build/src/Processors/Executors/StreamingFormatExecutor.cpp:58: DB::StreamingFormatExecutor::execute(DB::ReadBuffer&) @ 0x00000000168e49bc 15. /build/src/Interpreters/AsynchronousInsertQueue.cpp:1085: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x0000000014301c43 16. /build/src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:se190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000014305104 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 18. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:13:40.242529 [ 30860 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::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&&) @ 0x0000000014b93239 4. /build/src/Interpreters/ReplaceQueryParameterVisitor.cpp:105: DB::ReplaceQueryParameterVisitor::visitQueryParameter(std::shared_ptr&) @ 0x0000000014b92998 5. /build/src/Interpreters/evaluateConstantExpression.cpp:97: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x0000000014b85a02 6. /build/src/Interpreters/evaluateConstantExpression.cpp:196: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014b87bb9 7. /build/src/Processors/Formats/Impl/ValuesBlockInputFormat.cpp:548: DB::ValuesBlockInputFormat::parseExpression(DB::IColumn&, unsigned long) @ 0x0000000016af1df7 8. /build/src/Processors/Formats/Impl/ValuesBlockInputFormat.cpp:329: DB::ValuesBlockInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, unsigned long) @ 0x0000000016af0276 9. /build/src/Processors/Formats/Impl/ValuesBlockInputFormat.cpp:129: DB::ValuesBlockInputFormat::read() @ 0x0000000016aef3ee 10. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 11. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 12. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 13. /build/src/Processors/Executors/StreamingFormatExecutor.cpp:77: DB::StreamingFormatExecutor::execute() @ 0x00000000168e4b6a 14. /build/src/Processors/Executors/StreamingFormatExecutor.cpp:58: DB::StreamingFormatExecutor::execute(DB::ReadBuffer&) @ 0x00000000168e49bc 15. /build/src/Interpreters/AsynchronousInsertQueue.cpp:1085: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x0000000014301c43 16. /build/src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:se190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000014305104 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 18. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:13:40.673851 [ 5990 ] {7950be7a-2dda-467b-bac7-4ef648675c28} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_5o85qiql.t_async_insert_params (id) FORMAT Values' with query id afb66970-d795-4c2a-9660-f64bba4d2c92. DB::Exception: Cannot convert string 'Hello' to type UInt64 2025.07.13 02:13:40.766016 [ 30860 ] {afb66970-d795-4c2a-9660-f64bba4d2c92} 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]:36386) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014b78237 5. /build/src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014b75587 6. /build/src/Processors/Formats/Impl/ValuesBlockInputFormat.cpp:555: DB::ValuesBlockInputFormat::parseExpression(DB::IColumn&, unsigned long) @ 0x0000000016af1e3f 7. /build/src/Processors/Formats/Impl/ValuesBlockInputFormat.cpp:329: DB::ValuesBlockInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, unsigned long) @ 0x0000000016af0276 8. /build/src/Processors/Formats/Impl/ValuesBlockInputFormat.cpp:129: DB::ValuesBlockInputFormat::read() @ 0x0000000016aef3ee 9. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 10. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 11. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 12. /build/src/Processors/Executors/StreamingFormatExecutor.cpp:77: DB::StreamingFormatExecutor::execute() @ 0x00000000168e4b6a 13. /build/src/Processors/Executors/StreamingFormatExecutor.cpp:58: DB::StreamingFormatExecutor::execute(DB::ReadBuffer&) @ 0x00000000168e49bc 14. /build/src/Interpreters/AsynchronousInsertQueue.cpp:1085: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x0000000014301c43 15. /build/src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:se190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000014305104 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 17. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 20. ? @ 0x00007f7210eb6ac3 21. ? @ 0x00007f7210f48850 2025.07.13 02:13:40.793608 [ 30860 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014b78237 5. /build/src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014b75587 6. /build/src/Processors/Formats/Impl/ValuesBlockInputFormat.cpp:555: DB::ValuesBlockInputFormat::parseExpression(DB::IColumn&, unsigned long) @ 0x0000000016af1e3f 7. /build/src/Processors/Formats/Impl/ValuesBlockInputFormat.cpp:329: DB::ValuesBlockInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, unsigned long) @ 0x0000000016af0276 8. /build/src/Processors/Formats/Impl/ValuesBlockInputFormat.cpp:129: DB::ValuesBlockInputFormat::read() @ 0x0000000016aef3ee 9. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 10. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 11. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 12. /build/src/Processors/Executors/StreamingFormatExecutor.cpp:77: DB::StreamingFormatExecutor::execute() @ 0x00000000168e4b6a 13. /build/src/Processors/Executors/StreamingFormatExecutor.cpp:58: DB::StreamingFormatExecutor::execute(DB::ReadBuffer&) @ 0x00000000168e49bc 14. /build/src/Interpreters/AsynchronousInsertQueue.cpp:1085: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x0000000014301c43 15. /build/src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:se190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000014305104 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 17. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 20. ? @ 0x00007f7210eb6ac3 21. ? @ 0x00007f7210f48850 2025.07.13 02:13:40.835877 [ 31793 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:58596, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fc62e75 3. /build/src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000fc623ee 4. /build/src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000fc62923 5. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 6. /build/src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000001680643e 7. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 12. ? @ 0x00007f7210eb6ac3 13. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:40.838596 [ 31793 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:58596, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fc62e75 3. /build/src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000fc623ee 4. /build/src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000fc62923 5. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 6. /build/src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000001680643e 7. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 12. ? @ 0x00007f7210eb6ac3 13. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:41.132180 [ 30862 ] {e60ec483-a130-416e-b13d-18a3bc46aa38} executeQuery: Code: 520. DB::Exception: Cannot drop/detach dictionary test_gg5yl5xv.02181_test_dictionary 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]:58568) (comment: 02181_dictionary_attach_detach.sql) (query 6, line 22) (in query: DETACH TABLE 02181_test_dictionary;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Storages/StorageDictionary.cpp:162: DB::StorageDictionary::checkTableCanBeDropped(std::shared_ptr) const @ 0x0000000015c77ecc 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001483316b 6. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 7. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:13:41.154665 [ 30862 ] {} TCPHandler: Code: 520. DB::Exception: Cannot drop/detach dictionary test_gg5yl5xv.02181_test_dictionary as table, use DROP DICTIONARY or DETACH DICTIONARY query instead. (CANNOT_DETACH_DICTIONARY_AS_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Storages/StorageDictionary.cpp:162: DB::StorageDictionary::checkTableCanBeDropped(std::shared_ptr) const @ 0x0000000015c77ecc 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001483316b 6. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 7. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:13:41.243083 [ 5998 ] {5c2b8eb1-d891-43f6-9304-ca7fe6f81c8f} 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 SELECT toStartOfYear(toDate(16433), 'Asia/Istanbul'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54694) (comment: 00189_time_zones_long.sql) (query 74, line 113) (in query: SELECT toStartOfYear(toDate(16433), 'Asia/Istanbul');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/IFunctionDateOrDateTime.h:63: DB::FunctionDateOrDateTimeBase::checkArguments(std::vector> const&, bool) const @ 0x000000000e7354f8 5. /build/src/Functions/FunctionDateOrDateTimeToDateOrDate32.h:37: DB::FunctionDateOrDateTimeToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e7e2198 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:41.254745 [ 5998 ] {} 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 SELECT toStartOfYear(toDate(16433), 'Asia/Istanbul'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/IFunctionDateOrDateTime.h:63: DB::FunctionDateOrDateTimeBase::checkArguments(std::vector> const&, bool) const @ 0x000000000e7354f8 5. /build/src/Functions/FunctionDateOrDateTimeToDateOrDate32.h:37: DB::FunctionDateOrDateTimeToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e7e2198 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:41.351205 [ 5117 ] {36c6bd55-e123-4585-88fd-d7ca67beb075} 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]:58604) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, int&&) @ 0x000000000b96972b 4. /build/src/Functions/h3EdgeLengthM.cpp:89: DB::(anonymous namespace)::FunctionH3EdgeLengthM::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c12ad8d 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:13:41.365644 [ 5117 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, int&&) @ 0x000000000b96972b 4. /build/src/Functions/h3EdgeLengthM.cpp:89: DB::(anonymous namespace)::FunctionH3EdgeLengthM::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c12ad8d 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:13:41.382005 [ 10909 ] {8fe15d47-a4f0-43aa-8f99-7a5e3cc21947} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_5o85qiql.t_async_insert_params (id) FORMAT Values' with query id fc0453bc-1291-49ef-aad1-8b77f2066e46. 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:13:41.392744 [ 30862 ] {c211883d-043f-4565-880d-7c9130efdb5c} executeQuery: Code: 80. DB::Exception: Cannot ATTACH TABLE test_gg5yl5xv.`02181_test_dictionary`, it is a Dictionary. (INCORRECT_QUERY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58568) (comment: 02181_dictionary_attach_detach.sql) (query 7, line 23) (in query: ATTACH TABLE 02181_test_dictionary;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1564: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818af7 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:13:41.400994 [ 30862 ] {} TCPHandler: Code: 80. DB::Exception: Cannot ATTACH TABLE test_gg5yl5xv.`02181_test_dictionary`, it is a Dictionary. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1564: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818af7 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:13:41.410051 [ 30860 ] {fc0453bc-1291-49ef-aad1-8b77f2066e46} 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]:36386) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::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&&) @ 0x0000000014b93239 4. /build/src/Interpreters/ReplaceQueryParameterVisitor.cpp:105: DB::ReplaceQueryParameterVisitor::visitQueryParameter(std::shared_ptr&) @ 0x0000000014b92998 5. /build/src/Interpreters/evaluateConstantExpression.cpp:97: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x0000000014b85a02 6. /build/src/Interpreters/evaluateConstantExpression.cpp:196: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014b87bb9 7. /build/src/Processors/Formats/Impl/ValuesBlockInputFormat.cpp:548: DB::ValuesBlockInputFormat::parseExpression(DB::IColumn&, unsigned long) @ 0x0000000016af1df7 8. /build/src/Processors/Formats/Impl/ValuesBlockInputFormat.cpp:329: DB::ValuesBlockInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, unsigned long) @ 0x0000000016af0276 9. /build/src/Processors/Formats/Impl/ValuesBlockInputFormat.cpp:129: DB::ValuesBlockInputFormat::read() @ 0x0000000016aef3ee 10. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 11. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 12. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 13. /build/src/Processors/Executors/StreamingFormatExecutor.cpp:77: DB::StreamingFormatExecutor::execute() @ 0x00000000168e4b6a 14. /build/src/Processors/Executors/StreamingFormatExecutor.cpp:58: DB::StreamingFormatExecutor::execute(DB::ReadBuffer&) @ 0x00000000168e49bc 15. /build/src/Interpreters/AsynchronousInsertQueue.cpp:1085: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x0000000014301c43 16. /build/src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:se190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000014305104 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 18. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:13:41.416426 [ 30860 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::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&&) @ 0x0000000014b93239 4. /build/src/Interpreters/ReplaceQueryParameterVisitor.cpp:105: DB::ReplaceQueryParameterVisitor::visitQueryParameter(std::shared_ptr&) @ 0x0000000014b92998 5. /build/src/Interpreters/evaluateConstantExpression.cpp:97: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x0000000014b85a02 6. /build/src/Interpreters/evaluateConstantExpression.cpp:196: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014b87bb9 7. /build/src/Processors/Formats/Impl/ValuesBlockInputFormat.cpp:548: DB::ValuesBlockInputFormat::parseExpression(DB::IColumn&, unsigned long) @ 0x0000000016af1df7 8. /build/src/Processors/Formats/Impl/ValuesBlockInputFormat.cpp:329: DB::ValuesBlockInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, unsigned long) @ 0x0000000016af0276 9. /build/src/Processors/Formats/Impl/ValuesBlockInputFormat.cpp:129: DB::ValuesBlockInputFormat::read() @ 0x0000000016aef3ee 10. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 11. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 12. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 13. /build/src/Processors/Executors/StreamingFormatExecutor.cpp:77: DB::StreamingFormatExecutor::execute() @ 0x00000000168e4b6a 14. /build/src/Processors/Executors/StreamingFormatExecutor.cpp:58: DB::StreamingFormatExecutor::execute(DB::ReadBuffer&) @ 0x00000000168e49bc 15. /build/src/Interpreters/AsynchronousInsertQueue.cpp:1085: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x0000000014301c43 16. /build/src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:se190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000014305104 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 18. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:13:41.576695 [ 16758 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778c58 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168167bf 10. /build/src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000001680ff45 11. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:13:41.578593 [ 5117 ] {cba1f0d3-4e10-4602-9151-827a3b44d194} 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]:58604) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, int&&) @ 0x000000000b96972b 4. /build/src/Functions/h3HexAreaM2.cpp:84: DB::(anonymous namespace)::FunctionH3HexAreaM2::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c139bed 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:13:41.581643 [ 16758 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x0000000016810069 5. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 6. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 2025.07.13 02:13:41.596411 [ 5117 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, int&&) @ 0x000000000b96972b 4. /build/src/Functions/h3HexAreaM2.cpp:84: DB::(anonymous namespace)::FunctionH3HexAreaM2::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c139bed 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:13:42.013666 [ 5117 ] {8aa30584-6227-4603-86c2-a9b6e112aeaa} 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]:58604) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, int&&) @ 0x000000000b96972b 4. /build/src/Functions/h3HexAreaKm2.cpp:84: DB::(anonymous namespace)::FunctionH3HexAreaKm2::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c138dfa 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:13:42.035522 [ 5117 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, int&&) @ 0x000000000b96972b 4. /build/src/Functions/h3HexAreaKm2.cpp:84: DB::(anonymous namespace)::FunctionH3HexAreaKm2::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c138dfa 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:13:43.903220 [ 4622 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:13:46.286901 [ 31793 ] {e1acd979-eaf9-4d09-8249-c886c1ee3441} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_e76vk430.test1_00843' in scope SELECT * FROM test_e76vk430.test1_00843. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58658) (comment: 00843_optimize_predicate_and_rename_table.sql) (query 10, line 13) (in query: SELECT * FROM view_00843;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f633d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38a1e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f64224 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 14. /build/src/Storages/StorageView.cpp:176: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000015f54d6b 15. /build/src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000148b600e 16. /build/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&) @ 0x00000000148ad029 17. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 18. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 20. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:13:46.310533 [ 31793 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_e76vk430.test1_00843' in scope SELECT * FROM test_e76vk430.test1_00843. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f633d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38a1e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f64224 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 14. /build/src/Storages/StorageView.cpp:176: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000015f54d6b 15. /build/src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000148b600e 16. /build/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&) @ 0x00000000148ad029 17. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 18. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 20. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:13:47.294001 [ 27539 ] {aec2dc58-f693-46e4-a447-c8cfde906bd2} 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]:58694) (comment: 03261_tuple_map_object_to_json_cast.sql) (query 2, line 4) (in query: set allow_experimental_object_type = 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:13:47.338812 [ 27539 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:13:48.232149 [ 30862 ] {cf2e4d6a-6e5c-4dbc-930e-2aa680eca9d5} executeQuery: Code: 57. DB::Exception: Table test_7.test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58700) (comment: 03286_json_sub_object_subcolumn_correct_prefix.gen.sql) (query 3, line 7) (in query: create table test (json JSON(max_dynamic_paths=4)) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:13:48.287083 [ 30862 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:13:48.931331 [ 30862 ] {b1808fb0-5f68-41a7-a534-c6f3a44dc9cb} 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]:58718) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/array/arrayReduce.cpp:82: DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f59100c 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 6. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80f9b 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:13:48.977536 [ 30862 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/array/arrayReduce.cpp:82: DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f59100c 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 6. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80f9b 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:13:49.002223 [ 5988 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:13:49.085145 [ 30862 ] {09f92b4c-039e-4a73-a29a-0223cd6e024f} 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]:58718) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/array/arrayReduce.cpp:82: DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f59100c 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 6. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80f9b 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:13:49.151912 [ 30862 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/array/arrayReduce.cpp:82: DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f59100c 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 6. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80f9b 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:13:49.365014 [ 30862 ] {fb532443-3e58-4ecb-b1f6-d0034a6ef8ec} 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]:58718) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/array/arrayReduce.cpp:82: DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f59100c 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 6. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80f9b 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:13:49.369644 [ 30862 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/array/arrayReduce.cpp:82: DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f59100c 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 6. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80f9b 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:13:49.563026 [ 30862 ] {e53a7f79-57f8-4481-996c-f261079e2183} 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]:58718) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, String&&, String&&) @ 0x000000000e603ceb 4. /build/src/Functions/array/arrayReduce.cpp:90: DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f591642 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 6. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80f9b 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:13:49.580808 [ 30862 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, String&&, String&&) @ 0x000000000e603ceb 4. /build/src/Functions/array/arrayReduce.cpp:90: DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f591642 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 6. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80f9b 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:13:49.755037 [ 30862 ] {a3a1fb94-698d-4101-8111-a8d3782b86a7} 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]:58718) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/array/arrayReduce.cpp:82: DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f59100c 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 6. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80f9b 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:13:49.772199 [ 30862 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/array/arrayReduce.cpp:82: DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f59100c 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 6. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80f9b 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:13:50.283824 [ 27539 ] {cca0122e-33f3-4484-8614-51ac35678a17} 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: 13830481612736626689. (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]:40002) (comment: 02426_pod_array_overflow_3.sql) (query 1, line 1) (in query: SELECT * FROM format(Native, '\x01\x01\x01x\x0CArray(UInt8)\x01\x00\xBD\xEF\xBF\xBD\xEF\xBF\xBD\xEF');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000000e5746cb 4. /build/src/Formats/ReadSchemaUtils.cpp:287: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001689a17b 5. /build/src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001689af42 6. /build/src/TableFunctions/TableFunctionFormat.cpp:146: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000117577dd 7. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000130d4903 8. /build/src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000143537f2 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3da49 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:13:50.301422 [ 27539 ] {} 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: 13830481612736626689. (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000000e5746cb 4. /build/src/Formats/ReadSchemaUtils.cpp:287: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001689a17b 5. /build/src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001689af42 6. /build/src/TableFunctions/TableFunctionFormat.cpp:146: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000117577dd 7. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000130d4903 8. /build/src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000143537f2 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3da49 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:13:52.239102 [ 27539 ] {3fe9d732-44f0-43da-94cb-fcfce3607fc7} executeQuery: Code: 36. DB::Exception: Engine Memory doesn't support PARTITION_BY, PRIMARY_KEY, ORDER_BY or SAMPLE_BY clauses. Currently only the following engines have support for the feature: [OSS, AzureBlobStorage, KeeperMap, S3, MaterializedPostgreSQL, COSN, Redis, Hive, ReplicatedSummingMergeTree, ReplicatedVersionedCollapsingMergeTree, VersionedCollapsingMergeTree, ReplacingMergeTree, ReplicatedMergeTree, HDFS, EmbeddedRocksDB, ReplicatedCollapsingMergeTree, ReplicatedGraphiteMergeTree, ReplicatedReplacingMergeTree, SummingMergeTree, MergeTree, GraphiteMergeTree, CollapsingMergeTree, ReplicatedAggregatingMergeTree, AggregatingMergeTree]. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40014) (comment: 03285_default_engine_with_settings.sql) (query 7, line 11) (in query: -- Memory with ORDER BY is wrong CREATE TABLE example_table2 (id UInt32, data String) ORDER BY id SETTINGS max_part_loading_threads=8;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&) @ 0x000000000fdbec2b 4. /build/src/Storages/StorageFactory.cpp:187: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const::$_0::operator()(String, std::function) const @ 0x0000000015ca2f77 5. /build/src/Storages/StorageFactory.cpp:199: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x0000000015ca20cb 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001481ee32 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:13:52.255045 [ 27539 ] {} TCPHandler: Code: 36. DB::Exception: Engine Memory doesn't support PARTITION_BY, PRIMARY_KEY, ORDER_BY or SAMPLE_BY clauses. Currently only the following engines have support for the feature: [OSS, AzureBlobStorage, KeeperMap, S3, MaterializedPostgreSQL, COSN, Redis, Hive, ReplicatedSummingMergeTree, ReplicatedVersionedCollapsingMergeTree, VersionedCollapsingMergeTree, ReplacingMergeTree, ReplicatedMergeTree, HDFS, EmbeddedRocksDB, ReplicatedCollapsingMergeTree, ReplicatedGraphiteMergeTree, ReplicatedReplacingMergeTree, SummingMergeTree, MergeTree, GraphiteMergeTree, CollapsingMergeTree, ReplicatedAggregatingMergeTree, AggregatingMergeTree]. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&) @ 0x000000000fdbec2b 4. /build/src/Storages/StorageFactory.cpp:187: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const::$_0::operator()(String, std::function) const @ 0x0000000015ca2f77 5. /build/src/Storages/StorageFactory.cpp:199: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x0000000015ca20cb 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001481ee32 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:13:52.579700 [ 27539 ] {5f06271d-1967-400c-8c58-1ffbf91d38f0} executeQuery: Code: 115. DB::Exception: Unknown setting 'max_part_loading_threads': for storage Memory. (UNKNOWN_SETTING) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40014) (comment: 03285_default_engine_with_settings.sql) (query 8, line 14) (in query: -- Memory with max_part_loading_threads is wrong CREATE TABLE example_table2 (id UInt32, data String) SETTINGS max_part_loading_threads=8;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Core/BaseSettings.cpp:53: DB::BaseSettingsHelpers::throwSettingNotFound(std::basic_string_view>) @ 0x0000000013887da3 5. /build/src/Core/BaseSettings.h:629: DB::BaseSettings::set(std::basic_string_view>, DB::Field const&) @ 0x0000000015c5687d 6. /build/src/Core/BaseSettings.h:316: DB::MemorySettings::loadFromQuery(DB::ASTStorage&) @ 0x0000000015c558fd 7. /build/src/Storages/StorageMemory.cpp:639: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:se190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000015d4e4bd 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ca1a22 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001481ee32 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 14. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 15. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 20. ? @ 0x00007f7210eb6ac3 21. ? @ 0x00007f7210f48850 2025.07.13 02:13:52.587584 [ 27539 ] {} TCPHandler: Code: 115. DB::Exception: Unknown setting 'max_part_loading_threads': for storage Memory. (UNKNOWN_SETTING), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Core/BaseSettings.cpp:53: DB::BaseSettingsHelpers::throwSettingNotFound(std::basic_string_view>) @ 0x0000000013887da3 5. /build/src/Core/BaseSettings.h:629: DB::BaseSettings::set(std::basic_string_view>, DB::Field const&) @ 0x0000000015c5687d 6. /build/src/Core/BaseSettings.h:316: DB::MemorySettings::loadFromQuery(DB::ASTStorage&) @ 0x0000000015c558fd 7. /build/src/Storages/StorageMemory.cpp:639: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:se190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000015d4e4bd 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ca1a22 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001481ee32 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 14. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 15. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 20. ? @ 0x00007f7210eb6ac3 21. ? @ 0x00007f7210f48850 2025.07.13 02:13:54.011643 [ 12987 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:13:55.273567 [ 5822 ] {} ZooKeeperClient: Code: 999. Coordination::Exception: Session expired (fault injected on recv). (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x000000001652733b 3. /build/src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000170ca430 4. /build/src/Common/ZooKeeper/ZooKeeperImpl.cpp:1787: Coordination::ZooKeeper::maybeInjectRecvFault() @ 0x00000000170c3f11 5. /build/src/Common/ZooKeeper/ZooKeeperImpl.cpp:927: Coordination::ZooKeeper::receiveEvent() @ 0x00000000170c2f9e 6. /build/src/Common/ZooKeeper/ZooKeeperImpl.cpp:874: Coordination::ZooKeeper::receiveThread() @ 0x00000000170c26d8 7. /build/src/Common/ZooKeeper/ZooKeeperImpl.cpp:452: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl> const&, zkutil::ZooKeeperArgs const&, std::shared_ptr)::$_1>(Coordination::ZooKeeper::ZooKeeper(std::vector> const&, zkutil::ZooKeeperArgs const&, std::shared_ptr)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000170c9327 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:55.287892 [ 3975 ] {} test_7.t_light_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:13:55.291052 [ 3651 ] {} test_7.table_rename_with_ttl (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:13:55.293161 [ 3641 ] {} test_7.test (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:13:55.309731 [ 3861 ] {} test_7.trunc (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:13:55.314095 [ 3728 ] {} test_7.table_for_rename1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:13:55.317260 [ 3824 ] {} test_3.fetches_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:13:55.320677 [ 3814 ] {} test_7.replicated_table_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:13:55.351938 [ 3989 ] {} test_1.`03014_async_with_dedup_part_log` (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:13:55.374043 [ 3990 ] {} test_1.`03014_async_with_dedup_part_log` (9a000735-dc34-4879-9e30-baafd35bc614): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/table/test_1/03014_async_with_dedup_part_log/replicas/r1), cannot update queue. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:3795: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x0000000015e1b5bd 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013882414 6. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000138854aa 7. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000013885c47 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:55.372555 [ 3568 ] {} test_1.`03014_async_with_dedup_part_log` (9a000735-dc34-4879-9e30-baafd35bc614): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x000000001708ed1b 3. /build/src/Common/ZooKeeper/KeeperException.h:58: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x00000000170c45d3 4. /build/src/Common/ZooKeeper/ZooKeeperImpl.cpp:1557: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x00000000170c7d4a 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:1357: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001705f480 6. /build/src/Common/ZooKeeper/ZooKeeper.cpp:300: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001705efd5 7. /build/src/Common/ZooKeeper/ZooKeeper.cpp:374: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001705fbf2 8. /build/src/Common/ZooKeeper/ZooKeeper.cpp:336: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001705fb0b 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:929: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x00000000164e9406 10. /build/src/Storages/StorageReplicatedMergeTree.cpp:3833: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x0000000015e1b9b8 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013882414 12. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000138854aa 13. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000013885c47 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:55.380116 [ 3987 ] {} test_13.projection_broken_parts_2 (5fae9645-ef25-48d7-b2c1-b15d27f31703): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x000000001708ed1b 3. /build/src/Common/ZooKeeper/KeeperException.h:58: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x00000000170c45d3 4. /build/src/Common/ZooKeeper/ZooKeeperImpl.cpp:1557: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x00000000170c7d4a 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:1357: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001705f480 6. /build/src/Common/ZooKeeper/ZooKeeper.cpp:300: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001705efd5 7. /build/src/Common/ZooKeeper/ZooKeeper.cpp:374: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001705fbf2 8. /build/src/Common/ZooKeeper/ZooKeeper.cpp:336: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001705fb0b 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:929: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x00000000164e9406 10. /build/src/Storages/StorageReplicatedMergeTree.cpp:3833: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x0000000015e1b9b8 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013882414 12. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000138854aa 13. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000013885c47 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:55.385626 [ 4015 ] {} test_13.projection_broken_parts_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.13 02:13:55.384767 [ 3630 ] {} test_7.trunc (d980e042-94cd-4ca3-bcac-663c53848c80): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x000000001708ed1b 3. /build/src/Common/ZooKeeper/KeeperException.h:58: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x00000000170c45d3 4. /build/src/Common/ZooKeeper/ZooKeeperImpl.cpp:1557: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x00000000170c7d4a 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:1357: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001705f480 6. /build/src/Common/ZooKeeper/ZooKeeper.cpp:300: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001705efd5 7. /build/src/Common/ZooKeeper/ZooKeeper.cpp:374: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001705fbf2 8. /build/src/Common/ZooKeeper/ZooKeeper.cpp:336: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001705fb0b 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:929: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x00000000164e9406 10. /build/src/Storages/StorageReplicatedMergeTree.cpp:3833: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x0000000015e1b9b8 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013882414 12. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000138854aa 13. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000013885c47 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:55.554350 [ 3769 ] {} test_13.projection_broken_parts_2 (5fae9645-ef25-48d7-b2c1-b15d27f31703): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x000000001708ed1b 3. /build/src/Common/ZooKeeper/KeeperException.h:58: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x00000000170c45d3 4. /build/src/Common/ZooKeeper/ZooKeeperImpl.cpp:1499: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x00000000170c55fa 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:1240: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x00000000170630fc 6. /build/src/Common/ZooKeeper/ZooKeeper.cpp:605: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x0000000017062c47 7. /build/src/Common/ZooKeeper/ZooKeeper.cpp:626: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x00000000170637fd 8. /build/src/Common/ZooKeeper/ZooKeeper.cpp:664: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x0000000017063536 9. /build/src/Common/ZooKeeper/ZooKeeper.cpp:633: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x0000000017063398 10. /build/src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:640: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x00000000164e5036 11. /build/src/Storages/StorageReplicatedMergeTree.cpp:3798: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x0000000015e1b62b 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013882414 13. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000138854aa 14. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000013885c47 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:55.682746 [ 4004 ] {} test_7.trunc (d980e042-94cd-4ca3-bcac-663c53848c80): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/1166/test_7/mutations. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000000b9616ab 4. /build/src/Common/ZooKeeper/KeeperException.h:37: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000000b96104b 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:377: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001705fc51 6. /build/src/Common/ZooKeeper/ZooKeeper.cpp:336: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001705fb0b 7. /build/src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:929: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x00000000164e9406 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:653: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x00000000164e555b 9. /build/src/Storages/StorageReplicatedMergeTree.cpp:3798: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x0000000015e1b62b 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013882414 11. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000138854aa 12. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000013885c47 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 14. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:57.175961 [ 31799 ] {263a766b-88b3-4921-8457-1669cd8af848} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function gcd: In scope SELECT gcd(1280.1, 1024.1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40022) (comment: 00515_gcd_lcm.sql) (query 24, line 26) (in query: -- test gcd float select gcd(1280.1, 1024.1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000b94f4d3 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:57.211501 [ 31799 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function gcd: In scope SELECT gcd(1280.1, 1024.1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000b94f4d3 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:57.321879 [ 31799 ] {00a46560-398d-4030-a83c-21e27fbaeafc} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function gcd: In scope SELECT gcd(11.1, 121.1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40022) (comment: 00515_gcd_lcm.sql) (query 25, line 28) (in query: select gcd(11.1, 121.1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000b94f4d3 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:57.332157 [ 31799 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function gcd: In scope SELECT gcd(11.1, 121.1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000b94f4d3 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:57.393749 [ 31799 ] {fe44882a-9487-4047-86bd-4c73a0679ed6} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function gcd: In scope SELECT gcd(-256.1, 64.1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40022) (comment: 00515_gcd_lcm.sql) (query 26, line 29) (in query: select gcd(-256.1, 64.1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000b94f4d3 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:57.405897 [ 31799 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function gcd: In scope SELECT gcd(-256.1, 64.1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000b94f4d3 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:57.474342 [ 31799 ] {f06fa38a-f353-43ee-b9c2-a54829553e67} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function gcd: In scope SELECT gcd(1.1, 1.1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40022) (comment: 00515_gcd_lcm.sql) (query 27, line 30) (in query: select gcd(1.1, 1.1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000b94f4d3 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:57.483255 [ 31799 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function gcd: In scope SELECT gcd(1.1, 1.1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000b94f4d3 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:57.520482 [ 31831 ] {70ce70e9-5a50-4aad-9b83-4efd072c5473} 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]:40590) (comment: 02569_order_by_aggregation_result.sql) (in query: DROP DATABASE IF EXISTS test_kkkxzgek SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:13:57.526548 [ 31831 ] {70ce70e9-5a50-4aad-9b83-4efd072c5473} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:13:57.643511 [ 31799 ] {1879c954-366f-4db1-b7f2-33d8f05760c9} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function gcd: In scope SELECT gcd(4.1, 2.1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40022) (comment: 00515_gcd_lcm.sql) (query 28, line 31) (in query: select gcd(4.1, 2.1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000b94f4d3 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:57.666072 [ 31799 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function gcd: In scope SELECT gcd(4.1, 2.1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000b94f4d3 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:57.802548 [ 31799 ] {e81b655f-9677-4a57-a32a-01e91ba61e73} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function gcd: In scope SELECT gcd(15.1, 49.1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40022) (comment: 00515_gcd_lcm.sql) (query 29, line 32) (in query: select gcd(15.1, 49.1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000b94f4d3 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:57.825905 [ 31799 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function gcd: In scope SELECT gcd(15.1, 49.1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000b94f4d3 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:57.937831 [ 31799 ] {6959dfed-81bf-41a4-8071-639bfc6eea7a} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function gcd: In scope SELECT gcd(255.1, 254.1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40022) (comment: 00515_gcd_lcm.sql) (query 30, line 33) (in query: select gcd(255.1, 254.1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000b94f4d3 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:57.957435 [ 31799 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function gcd: In scope SELECT gcd(255.1, 254.1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000b94f4d3 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:58.088215 [ 31799 ] {af1d2520-7483-4bb6-9fb8-a4e4eb44f0db} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function lcm: In scope SELECT lcm(1280.1, 1024.1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40022) (comment: 00515_gcd_lcm.sql) (query 31, line 34) (in query: -- test lcm float select lcm(1280.1, 1024.1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000c7a9173 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:58.128610 [ 31799 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function lcm: In scope SELECT lcm(1280.1, 1024.1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000c7a9173 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:58.176054 [ 30811 ] {9d37c1a6-1ee5-487c-add0-7a443df7b757} executeQuery: Code: 1. DB::Exception: Resolved identifier 'p_partkey' in parent scope to expression 'test_11.part.p_partkey' with correlated column 'p_partkey'. In scope (SELECT min(ps_supplycost) FROM partsupp, supplier, nation, region WHERE (p_partkey = ps_partkey) AND (s_suppkey = ps_suppkey) AND (s_nationkey = n_nationkey) AND (n_regionkey = r_regionkey) AND (r_name = 'EUROPE')). (UNSUPPORTED_METHOD) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58622) (comment: 01095_tpch_like_smoke.sql) (query 21, line 140) (in query: select s_acctbal, s_name, n_name, p_partkey, p_mfgr, s_address, s_phone, s_comment from part, supplier, partsupp, nation, region where p_partkey = ps_partkey and s_suppkey = ps_suppkey and p_size = 15 and p_type like '%BRASS' and s_nationkey = n_nationkey and n_regionkey = r_regionkey and r_name = 'EUROPE' and ps_supplycost = ( select min(ps_supplycost) from partsupp, supplier, nation, region where p_partkey = ps_partkey and s_suppkey = ps_suppkey and s_nationkey = n_nationkey and n_regionkey = r_regionkey and r_name = 'EUROPE' ) order by s_acctbal desc, n_name, s_name, p_partkey limit 100;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String const&, String&&) @ 0x0000000013f68c6b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1382: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000013f4992c 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1544: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000013f4893d 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f392f4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3236a 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38a1e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3236a 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 31. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 2025.07.13 02:13:58.277929 [ 31799 ] {6c7fd33c-7c03-457c-bf49-271f92c12cbf} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function lcm: In scope SELECT lcm(11.1, 121.1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40022) (comment: 00515_gcd_lcm.sql) (query 32, line 36) (in query: select lcm(11.1, 121.1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000c7a9173 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:58.294189 [ 30811 ] {} TCPHandler: Code: 1. DB::Exception: Resolved identifier 'p_partkey' in parent scope to expression 'test_11.part.p_partkey' with correlated column 'p_partkey'. In scope (SELECT min(ps_supplycost) FROM partsupp, supplier, nation, region WHERE (p_partkey = ps_partkey) AND (s_suppkey = ps_suppkey) AND (s_nationkey = n_nationkey) AND (n_regionkey = r_regionkey) AND (r_name = 'EUROPE')). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String const&, String&&) @ 0x0000000013f68c6b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1382: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000013f4992c 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1544: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000013f4893d 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f392f4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3236a 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38a1e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3236a 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 31. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 2025.07.13 02:13:58.338514 [ 31799 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function lcm: In scope SELECT lcm(11.1, 121.1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000c7a9173 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:58.599254 [ 31799 ] {64283a13-1f04-4f54-b474-1ea16c0ac11c} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function lcm: In scope SELECT lcm(-256.1, 64.1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40022) (comment: 00515_gcd_lcm.sql) (query 33, line 37) (in query: select lcm(-256.1, 64.1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000c7a9173 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:58.607008 [ 31799 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function lcm: In scope SELECT lcm(-256.1, 64.1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000c7a9173 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:58.849885 [ 31799 ] {30ab1838-f2d2-4cdf-abd5-b3227c02f85a} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function lcm: In scope SELECT lcm(1.1, 1.1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40022) (comment: 00515_gcd_lcm.sql) (query 34, line 38) (in query: select lcm(1.1, 1.1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000c7a9173 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:58.904902 [ 16784 ] {8f983d9d-c815-4cff-98fa-a37d9641a15b} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'timestamp'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT timestamp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40050) (comment: 02834_timestamp_function.sql) (query 21, line 25) (in query: SELECT timestamp();), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000012c9192b 4. /build/src/Functions/FunctionHelpers.cpp:184: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c90171 5. /build/src/Functions/timestamp.cpp:49: DB::(anonymous namespace)::FunctionTimestamp::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e73b10e 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:58.921910 [ 16784 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'timestamp'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT timestamp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000012c9192b 4. /build/src/Functions/FunctionHelpers.cpp:184: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c90171 5. /build/src/Functions/timestamp.cpp:49: DB::(anonymous namespace)::FunctionTimestamp::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e73b10e 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:58.935934 [ 31799 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function lcm: In scope SELECT lcm(1.1, 1.1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000c7a9173 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:59.035000 [ 16784 ] {6cb7568b-a073-4758-964e-58f933ad21a4} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'timestamp'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT timestamp('2013-12-31 12:00:00', '12:00:00', ''). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40050) (comment: 02834_timestamp_function.sql) (query 22, line 26) (in query: SELECT timestamp('2013-12-31 12:00:00', '12:00:00', '');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000012c9192b 4. /build/src/Functions/FunctionHelpers.cpp:184: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c90171 5. /build/src/Functions/timestamp.cpp:49: DB::(anonymous namespace)::FunctionTimestamp::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e73b10e 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:59.036594 [ 5988 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:13:59.040408 [ 31799 ] {df52150b-586c-43f7-bc62-728baea32cd2} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function lcm: In scope SELECT lcm(4.1, 2.1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40022) (comment: 00515_gcd_lcm.sql) (query 35, line 39) (in query: select lcm(4.1, 2.1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000c7a9173 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:59.057343 [ 31799 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function lcm: In scope SELECT lcm(4.1, 2.1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000c7a9173 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:59.078356 [ 16784 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'timestamp'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT timestamp('2013-12-31 12:00:00', '12:00:00', ''). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000012c9192b 4. /build/src/Functions/FunctionHelpers.cpp:184: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c90171 5. /build/src/Functions/timestamp.cpp:49: DB::(anonymous namespace)::FunctionTimestamp::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e73b10e 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:59.198156 [ 31799 ] {1a05fa83-43c2-44ff-89c2-76a349993f77} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function lcm: In scope SELECT lcm(15.1, 49.1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40022) (comment: 00515_gcd_lcm.sql) (query 36, line 40) (in query: select lcm(15.1, 49.1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000c7a9173 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:59.216305 [ 31799 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function lcm: In scope SELECT lcm(15.1, 49.1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000c7a9173 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:59.221574 [ 16784 ] {82b30f93-b37e-4141-9a9f-8d8cf939a0cb} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'timestamp' to function 'timestamp'. Expected: String or FixedString, got: UInt8: In scope SELECT timestamp(1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40050) (comment: 02834_timestamp_function.sql) (query 23, line 27) (in query: SELECT timestamp(1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/timestamp.cpp:49: DB::(anonymous namespace)::FunctionTimestamp::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e73b10e 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:13:59.232530 [ 16784 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'timestamp' to function 'timestamp'. Expected: String or FixedString, got: UInt8: In scope SELECT timestamp(1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/timestamp.cpp:49: DB::(anonymous namespace)::FunctionTimestamp::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e73b10e 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:13:59.274275 [ 31799 ] {e5b4b13e-15a0-4cf7-8b46-9bbc5a7867cd} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function lcm: In scope SELECT lcm(255.1, 254.1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40022) (comment: 00515_gcd_lcm.sql) (query 37, line 41) (in query: select lcm(255.1, 254.1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000c7a9173 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:59.282492 [ 31799 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function lcm: In scope SELECT lcm(255.1, 254.1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000c7a9173 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a5791fe 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:13:59.326430 [ 16784 ] {59916ce5-689f-484f-bfcf-22390a1e75de} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'timestamp' to function 'timestamp'. Expected: String or FixedString, got: UInt8: In scope SELECT timestamp(1, 2). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40050) (comment: 02834_timestamp_function.sql) (query 24, line 28) (in query: SELECT timestamp(1, 2);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/timestamp.cpp:49: DB::(anonymous namespace)::FunctionTimestamp::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e73b10e 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:13:59.335389 [ 16784 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'timestamp' to function 'timestamp'. Expected: String or FixedString, got: UInt8: In scope SELECT timestamp(1, 2). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/timestamp.cpp:49: DB::(anonymous namespace)::FunctionTimestamp::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e73b10e 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:14:00.598150 [ 31788 ] {dce01822-42c9-4ad9-9a42-b97e81743e97} executeQuery: Code: 182. DB::Exception: Table expression test_3.merge1 AS __table1 does not support column __table1.Val in PREWHERE. In query SELECT Val FROM merge1 PREWHERE (Val = 65536) OR (Val = 2). (ILLEGAL_PREWHERE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47322) (comment: 02527_storage_merge_prewhere_different_type.sql) (query 7, line 9) (in query: SELECT Val FROM merge1 PREWHERE Val = 65536 OR Val = 2;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000141ee6ed 5. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000141ee3ea 6. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000141ee3ea 7. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000141ee3ea 8. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000141ee3ea 9. /build/src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000141ec35f 10. /build/src/Planner/Planner.cpp:1501: DB::Planner::buildPlanForQueryNode() @ 0x000000001489778c 11. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 13. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:14:00.617750 [ 31788 ] {} TCPHandler: Code: 182. DB::Exception: Table expression test_3.merge1 AS __table1 does not support column __table1.Val in PREWHERE. In query SELECT Val FROM merge1 PREWHERE (Val = 65536) OR (Val = 2). (ILLEGAL_PREWHERE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000141ee6ed 5. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000141ee3ea 6. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000141ee3ea 7. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000141ee3ea 8. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000141ee3ea 9. /build/src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000141ec35f 10. /build/src/Planner/Planner.cpp:1501: DB::Planner::buildPlanForQueryNode() @ 0x000000001489778c 11. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 13. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:14:02.747091 [ 6608 ] {33d4760c-ea00-4fae-96a0-3bee2f47025d} 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]:47372) (comment: 01329_compare_tuple_string_constant.sql) (query 1, line 1) (in query: SELECT tuple(1) < '';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/IO/ReadHelpers.cpp:95: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000000fb7e1e9 5. /build/src/IO/ReadHelpers.h:204: void DB::SerializationTuple::deserializeTextImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x0000000013c477c5 6. /build/src/Interpreters/convertFieldToType.cpp:578: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014b775e9 7. /build/src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014b75587 8. /build/src/Functions/FunctionsComparison.h:925: DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c999a91 9. /build/src/Functions/FunctionsComparison.h:1361: DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c980ddf 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 29. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 30. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 2025.07.13 02:14:02.769715 [ 6608 ] {} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected '(' at end of stream.: while converting '' to Tuple(UInt8): In scope SELECT tuple(1) < ''. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/IO/ReadHelpers.cpp:95: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000000fb7e1e9 5. /build/src/IO/ReadHelpers.h:204: void DB::SerializationTuple::deserializeTextImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x0000000013c477c5 6. /build/src/Interpreters/convertFieldToType.cpp:578: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014b775e9 7. /build/src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014b75587 8. /build/src/Functions/FunctionsComparison.h:925: DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c999a91 9. /build/src/Functions/FunctionsComparison.h:1361: DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c980ddf 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 29. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 30. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 2025.07.13 02:14:03.039983 [ 6608 ] {6b8e45d3-f75d-4ea0-b653-d0e7c102ba34} 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]:47372) (comment: 01329_compare_tuple_string_constant.sql) (query 2, line 2) (in query: SELECT tuple(1) < materialize('');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000dda78ab 4. /build/src/DataTypes/getLeastSupertype.cpp:69: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x0000000013b8f59e 5. /build/src/DataTypes/getLeastSupertype.cpp:401: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000013b92b3b 6. /build/src/Functions/FunctionsComparison.h:1149: DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000c99aa33 7. /build/src/Functions/FunctionsComparison.h:1429: DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c981974 8. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 9. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013ec18ac 14. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013ec09aa 15. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016b30052 16. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016cdda71 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000130d8a1a 18. /build/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>>&) @ 0x00000000148a05bd 19. /build/src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000001489a16a 20. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 22. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:14:03.047614 [ 31831 ] {b0c3e009-b05f-4d34-9d74-84564e3ff316} executeQuery: Code: 479. DB::Exception: Unknown disk name __un_exists_disk while execute function filesystemCapacity: In scope SELECT filesystemCapacity('__un_exists_disk'). (UNKNOWN_DISK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47366) (comment: 02457_filesystem_function.sql) (query 3, line 6) (in query: select filesystemCapacity('__un_exists_disk');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000b202acb 4. /build/src/Functions/filesystem.cpp:99: DB::(anonymous namespace)::FilesystemImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8407bb 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:14:03.054290 [ 6608 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Tuple(UInt8), String because some of them are Tuple and some of them are not. (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000dda78ab 4. /build/src/DataTypes/getLeastSupertype.cpp:69: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x0000000013b8f59e 5. /build/src/DataTypes/getLeastSupertype.cpp:401: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000013b92b3b 6. /build/src/Functions/FunctionsComparison.h:1149: DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000c99aa33 7. /build/src/Functions/FunctionsComparison.h:1429: DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c981974 8. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 9. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013ec18ac 14. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013ec09aa 15. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016b30052 16. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016cdda71 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000130d8a1a 18. /build/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>>&) @ 0x00000000148a05bd 19. /build/src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000001489a16a 20. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 22. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:14:03.061167 [ 31831 ] {} TCPHandler: Code: 479. DB::Exception: Unknown disk name __un_exists_disk while execute function filesystemCapacity: In scope SELECT filesystemCapacity('__un_exists_disk'). (UNKNOWN_DISK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000b202acb 4. /build/src/Functions/filesystem.cpp:99: DB::(anonymous namespace)::FilesystemImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8407bb 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:14:04.253866 [ 12973 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:14:04.595320 [ 6608 ] {37336767-1c87-4508-9c88-928f8e6c6a20} 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]:47394) (comment: 01669_join_or_duplicates.sql) (query 1, line 1) (in query: select '1 left', * from (select 1 as x, 2 as y) t1 left join (select 1 as xx, 2 as yy from numbers(1)) t2 on x = xx or y = yy;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Planner/PlannerJoins.cpp:1267: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x00000000148e4aa4 5. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0e7d2 6. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 7. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:14:04.640316 [ 6608 ] {} TCPHandler: Code: 48. DB::Exception: Only `hash` join supports multiple ORs for keys in JOIN ON section. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Planner/PlannerJoins.cpp:1267: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x00000000148e4aa4 5. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0e7d2 6. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 7. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:14:09.257069 [ 12974 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:14:10.390401 [ 30862 ] {c09575cf-7430-403f-bf0e-0edb66b94850} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=853, jobs=818). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40038) (comment: 01166_truncate_multiple_partitions.sql) (query 18, line 23) (in query: insert into trunc select * from numbers(20);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbdd1d3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd751c 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 7. /build/src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x00000000168cf907 8. /build/src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000001680710e 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:14:10.415171 [ 30862 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=853, jobs=818). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbdd1d3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd751c 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 7. /build/src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x00000000168cf907 8. /build/src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000001680710e 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:14:12.966476 [ 30811 ] {15a4bed7-6549-4bbb-8eb9-981111553e45} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda7a6 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbdb1ad 7. /build/src/Interpreters/ConcurrentHashJoin.cpp:170: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x0000000014487e5f 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x00000000148e457a 9. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0e7d2 10. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 11. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 12. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:14:13.209373 [ 30811 ] {15a4bed7-6549-4bbb-8eb9-981111553e45} 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]:58622) (comment: 01095_tpch_like_smoke.sql) (query 34, line 352) (in query: select nation, o_year, sum(amount) as sum_profit from ( select n_name as nation, extract(year from o_orderdate) as o_year, l_extendedprice * (1 - l_discount) - ps_supplycost * l_quantity as amount from part, supplier, lineitem, partsupp, orders, nation where s_suppkey = l_suppkey and ps_suppkey = l_suppkey and ps_partkey = l_partkey and p_partkey = l_partkey and o_orderkey = l_orderkey and s_nationkey = n_nationkey and p_name like '%green%' ) as profit group by nation, o_year order by nation, o_year desc;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda7a6 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbdb1ad 7. /build/src/Interpreters/ConcurrentHashJoin.cpp:170: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x0000000014487e5f 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x00000000148e457a 9. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0e7d2 10. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 11. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 12. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:14:13.234262 [ 30811 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda7a6 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbdb1ad 7. /build/src/Interpreters/ConcurrentHashJoin.cpp:170: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x0000000014487e5f 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x00000000148e457a 9. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0e7d2 10. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 11. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 12. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:14:14.311146 [ 32771 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:14:17.283317 [ 4922 ] {479ffc6b-08b2-4e27-b8dc-23fee35f7884} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 18.32 MiB (attempt to allocate chunk of 9.16 MiB bytes), maximum: 9.54 MiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39078) (comment: 01019_Buffer_and_max_memory_usage.sql) (query 11, line 33) (in query: INSERT INTO buffer_ SELECT toUInt64(number) FROM system.numbers LIMIT toUInt64(10e6+1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000000fb2de96 4. /build/src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2ca0a 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2c5bf 6. /build/src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000fa9410c 7. /build/src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000000fa92c7f 8. /build/src/Common/PODArray.h:152: void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::reserve_exact<>(unsigned long) @ 0x000000000a154727 9. /build/src/Interpreters/Squashing.cpp:175: DB::Squashing::squash(std::vector>&&, DB::CollectionOfDerivedItems&&) @ 0x00000000149caec9 10. /build/src/Interpreters/Squashing.cpp:45: DB::Squashing::squash(DB::Chunk&&) @ 0x00000000149ca482 11. /build/src/Processors/Transforms/ApplySquashingTransform.h:35: DB::ApplySquashingTransform::onConsume(DB::Chunk) @ 0x00000000148569d9 12. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 14. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 20. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168cfe81 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:14:17.291009 [ 4922 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 18.32 MiB (attempt to allocate chunk of 9.16 MiB bytes), maximum: 9.54 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000000fb2de96 4. /build/src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2ca0a 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2c5bf 6. /build/src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000fa9410c 7. /build/src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000000fa92c7f 8. /build/src/Common/PODArray.h:152: void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::reserve_exact<>(unsigned long) @ 0x000000000a154727 9. /build/src/Interpreters/Squashing.cpp:175: DB::Squashing::squash(std::vector>&&, DB::CollectionOfDerivedItems&&) @ 0x00000000149caec9 10. /build/src/Interpreters/Squashing.cpp:45: DB::Squashing::squash(DB::Chunk&&) @ 0x00000000149ca482 11. /build/src/Processors/Transforms/ApplySquashingTransform.h:35: DB::ApplySquashingTransform::onConsume(DB::Chunk) @ 0x00000000148569d9 12. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 14. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 20. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168cfe81 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x00000000168cf907 5. /build/src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000001680710e 6. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 2025.07.13 02:14:19.299807 [ 12991 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:14:21.103845 [ 30860 ] {9eb082fa-f752-42a3-a7ac-1444b5157b35} 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]:39104) (comment: 01037_zookeeper_check_table_empty_pk.sql) (query 10, line 19) (in query: CREATE TABLE replicated_mt_without_pk (`SomeField1` Int64, `SomeField2` Double) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/test_01037/replicated_mt_without_pk', '1') ORDER BY tuple() SETTINGS index_granularity = 45053, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 230118629, compact_parts_max_granules_to_buffer = 81, compact_parts_merge_max_bytes_to_prefetch_part = 1039216, merge_max_block_size = 20101, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 717203, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 4945028090, index_granularity_bytes = 11011710, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 40, 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 = 48406, primary_key_compress_block_size = 32661, use_primary_key_cache = false, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000013cc1696 5. /build/src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013cc32f5 6. /build/src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc384b 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:14:21.156244 [ 30860 ] {} TCPHandler: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000013cc1696 5. /build/src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013cc32f5 6. /build/src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc384b 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:14:21.666291 [ 27693 ] {74b1ade7-54f0-45e9-9ed7-621acb7dce6e} executeQuery: Code: 159. DB::Exception: Timeout exceeded (180 s) while flushing system log 'DB::SystemLogQueue'. (TIMEOUT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37312) (comment: 03014_async_with_dedup_part_log_rmt.sql) (query 7, line 11) (in query: SYSTEM FLUSH LOGS;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Common/SystemLogBase.cpp:168: DB::SystemLogQueue::waitFlush(long, bool) @ 0x000000000fbee407 5. /build/src/Interpreters/SystemLog.cpp:437: DB::SystemLogs::flush(bool, std::vector> const&) @ 0x0000000014a1ea9f 6. /build/src/Interpreters/InterpreterSystemQuery.cpp:796: DB::InterpreterSystemQuery::execute() @ 0x0000000014bd5a4e 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:14:21.698895 [ 27693 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded (180 s) while flushing system log 'DB::SystemLogQueue'. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Common/SystemLogBase.cpp:168: DB::SystemLogQueue::waitFlush(long, bool) @ 0x000000000fbee407 5. /build/src/Interpreters/SystemLog.cpp:437: DB::SystemLogs::flush(bool, std::vector> const&) @ 0x0000000014a1ea9f 6. /build/src/Interpreters/InterpreterSystemQuery.cpp:796: DB::InterpreterSystemQuery::execute() @ 0x0000000014bd5a4e 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:14:22.499412 [ 16784 ] {53ec65d1-cc7a-4faf-92f2-327e032e1cec} executeQuery: Code: 36. DB::Exception: Codec Delta is only applicable for data types of size 1, 2, 4, 8 bytes. Given type Decimal(38, 10). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51732) (comment: 01380_coded_delta_exception_code.sql) (query 1, line 1) (in query: CREATE TABLE delta_codec_synthetic (`id` Decimal(38, 10) CODEC(Delta, ZSTD(22))) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 16793, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.5234461426734924, 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 = 92116842, compact_parts_max_granules_to_buffer = 5, compact_parts_merge_max_bytes_to_prefetch_part = 4350810, merge_max_block_size = 21095, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 8140159681, vertical_merge_algorithm_min_rows_to_activate = 125925, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 11647625, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 89, 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 = 89932, primary_key_compress_block_size = 48705, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Compression/CompressionCodecDelta.cpp:183: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl[abi:se190107] (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x000000001786b653 5. /build/src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000001788beec 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013b9f869 7. /build/src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000013b9fb5d 8. /build/src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000001788ae8d 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000001480b791 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001480c764 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000001481759b 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:14:22.513415 [ 16784 ] {} TCPHandler: Code: 36. DB::Exception: Codec Delta is only applicable for data types of size 1, 2, 4, 8 bytes. Given type Decimal(38, 10). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Compression/CompressionCodecDelta.cpp:183: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl[abi:se190107] (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x000000001786b653 5. /build/src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000001788beec 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013b9f869 7. /build/src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000013b9fb5d 8. /build/src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000001788ae8d 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000001480b791 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001480c764 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000001481759b 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:14:22.846839 [ 16784 ] {04d49295-3127-488e-b5d0-9ee8fab21471} executeQuery: Code: 36. DB::Exception: Codec DoubleDelta is only applicable for data types of size 1, 2, 4, 8 bytes. Given type Decimal(38, 10). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51732) (comment: 01380_coded_delta_exception_code.sql) (query 2, line 2) (in query: CREATE TABLE delta_codec_synthetic (`id` Decimal(38, 10) CODEC(DoubleDelta, ZSTD(22))) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 16793, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.5234461426734924, 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 = 92116842, compact_parts_max_granules_to_buffer = 5, compact_parts_merge_max_bytes_to_prefetch_part = 4350810, merge_max_block_size = 21095, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 8140159681, vertical_merge_algorithm_min_rows_to_activate = 125925, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 11647625, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 89, 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 = 89932, primary_key_compress_block_size = 48705, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Compression/CompressionCodecDoubleDelta.cpp:454: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl[abi:se190107] (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x000000001787af33 5. /build/src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000001788beec 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013b9f869 7. /build/src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000013b9fb5d 8. /build/src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000001788ae8d 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000001480b791 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001480c764 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000001481759b 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:14:22.879266 [ 16784 ] {} TCPHandler: Code: 36. DB::Exception: Codec DoubleDelta is only applicable for data types of size 1, 2, 4, 8 bytes. Given type Decimal(38, 10). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Compression/CompressionCodecDoubleDelta.cpp:454: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl[abi:se190107] (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x000000001787af33 5. /build/src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000001788beec 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013b9f869 7. /build/src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000013b9fb5d 8. /build/src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000001788ae8d 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000001480b791 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001480c764 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000001481759b 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:14:23.056080 [ 30811 ] {9af6c391-38bd-4733-b215-0dda5aba07a2} 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]:38384) (comment: 03231_pr_duplicate_announcement_2.sql) (in query: DROP DATABASE IF EXISTS test_fs2aqtwn SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:14:23.060185 [ 30811 ] {9af6c391-38bd-4733-b215-0dda5aba07a2} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:14:23.105045 [ 16784 ] {3077fe6e-e182-4262-9193-effa65a4e019} executeQuery: Code: 36. DB::Exception: Codec Gorilla is only applicable for data types of size 1, 2, 4, 8 bytes. Given type Decimal(38, 10). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51732) (comment: 01380_coded_delta_exception_code.sql) (query 3, line 3) (in query: CREATE TABLE delta_codec_synthetic (`id` Decimal(38, 10) CODEC(Gorilla, ZSTD(22))) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 16793, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.5234461426734924, 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 = 92116842, compact_parts_max_granules_to_buffer = 5, compact_parts_merge_max_bytes_to_prefetch_part = 4350810, merge_max_block_size = 21095, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 8140159681, vertical_merge_algorithm_min_rows_to_activate = 125925, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 11647625, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 89, 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 = 89932, primary_key_compress_block_size = 48705, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Compression/CompressionCodecGorilla.cpp:350: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl[abi:se190107] (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x000000001787e873 5. /build/src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000001788beec 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013b9f869 7. /build/src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000013b9fb5d 8. /build/src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000001788ae8d 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000001480b791 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001480c764 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000001481759b 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:14:23.160858 [ 16784 ] {} TCPHandler: Code: 36. DB::Exception: Codec Gorilla is only applicable for data types of size 1, 2, 4, 8 bytes. Given type Decimal(38, 10). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Compression/CompressionCodecGorilla.cpp:350: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl[abi:se190107] (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x000000001787e873 5. /build/src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000001788beec 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013b9f869 7. /build/src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000013b9fb5d 8. /build/src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000001788ae8d 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000001480b791 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001480c764 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000001481759b 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:14:23.211535 [ 4281 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {79e989a3-28e6-4868-84fc-6251e7368e89::202507_185_195_2}: Code: 241. DB::Exception: Thread memory tracker: fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000000fb2dc4b 4. /build/src/Common/MemoryTracker.cpp:196: MemoryTracker::injectFault() const @ 0x000000000fb2b6cd 5. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:153: DB::MergePlainMergeTreeTask::finish() @ 0x0000000016593639 6. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:72: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000016592af2 7. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 8. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:14:23.358719 [ 16784 ] {c1fc39cd-18c4-477b-ac7b-9e63a30047d5} executeQuery: Code: 433. DB::Exception: Argument value for DoubleDelta codec can be 1, 2, 4 or 8, given 3. (ILLEGAL_CODEC_PARAMETER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51732) (comment: 01380_coded_delta_exception_code.sql) (query 4, line 5) (in query: CREATE TABLE delta_codec_synthetic (`id` UInt64 CODEC(DoubleDelta(3), ZSTD(22))) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 16793, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.5234461426734924, 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 = 92116842, compact_parts_max_granules_to_buffer = 5, compact_parts_merge_max_bytes_to_prefetch_part = 4350810, merge_max_block_size = 21095, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 8140159681, vertical_merge_algorithm_min_rows_to_activate = 125925, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 11647625, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 89, 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 = 89932, primary_key_compress_block_size = 48705, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000b152a4b 4. /build/src/Compression/CompressionCodecDoubleDelta.cpp:573: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl[abi:se190107] (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x000000001787b267 5. /build/src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000001788beec 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013b9f869 7. /build/src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000013b9fb5d 8. /build/src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000001788ae8d 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000001480b791 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001480c764 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000001481759b 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:14:23.378315 [ 16784 ] {} TCPHandler: Code: 433. DB::Exception: Argument value for DoubleDelta codec can be 1, 2, 4 or 8, given 3. (ILLEGAL_CODEC_PARAMETER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000b152a4b 4. /build/src/Compression/CompressionCodecDoubleDelta.cpp:573: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl[abi:se190107] (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x000000001787b267 5. /build/src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000001788beec 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013b9f869 7. /build/src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000013b9fb5d 8. /build/src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000001788ae8d 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000001480b791 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001480c764 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000001481759b 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:14:23.417732 [ 31788 ] {e4b34ffd-5442-45ec-84e6-0dc2acb2fa1f} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51692) (comment: 01050_clickhouse_dict_source_with_subquery.sql) (query 9, line 15) (in query: DROP DICTIONARY IF EXISTS test_7.test_dict_01051_d), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833ede 5. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 7. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 10. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:14:23.429227 [ 31788 ] {} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833ede 5. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 7. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 10. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:14:23.616492 [ 16784 ] {dda81158-6803-4ce3-a0dc-39fae3c511e7} executeQuery: Code: 433. DB::Exception: Gorilla codec argument must be unsigned integer. (ILLEGAL_CODEC_PARAMETER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51732) (comment: 01380_coded_delta_exception_code.sql) (query 5, line 6) (in query: CREATE TABLE delta_codec_synthetic (`id` UInt64 CODEC(Gorilla('hello, world'), ZSTD(22))) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 16793, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.5234461426734924, 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 = 92116842, compact_parts_max_granules_to_buffer = 5, compact_parts_merge_max_bytes_to_prefetch_part = 4350810, merge_max_block_size = 21095, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 8140159681, vertical_merge_algorithm_min_rows_to_activate = 125925, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 11647625, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 89, 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 = 89932, primary_key_compress_block_size = 48705, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Compression/CompressionCodecGorilla.cpp:470: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl[abi:se190107] (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x000000001787ea28 5. /build/src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000001788beec 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013b9f869 7. /build/src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000013b9fb5d 8. /build/src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000001788ae8d 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000001480b791 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001480c764 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000001481759b 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:14:23.645310 [ 16784 ] {} TCPHandler: Code: 433. DB::Exception: Gorilla codec argument must be unsigned integer. (ILLEGAL_CODEC_PARAMETER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Compression/CompressionCodecGorilla.cpp:470: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl[abi:se190107] (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x000000001787ea28 5. /build/src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000001788beec 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013b9f869 7. /build/src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000013b9fb5d 8. /build/src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000001788ae8d 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000001480b791 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001480c764 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000001481759b 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:14:24.230727 [ 31788 ] {f07bfe2a-1976-499b-afc5-f24fd7019a63} executeQuery: Code: 57. DB::Exception: Table test_7.test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51734) (comment: 01523_date_time_compare_with_date_literal.sql) (query 2, line 3) (in query: CREATE TABLE test (`timestamp` DateTime) ENGINE = MergeTree ORDER BY timestamp SETTINGS index_granularity = 26573, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 373783822, compact_parts_max_granules_to_buffer = 140, compact_parts_merge_max_bytes_to_prefetch_part = 10397665, merge_max_block_size = 10988, 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 = 11683209, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 89, 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 = 71041, primary_key_compress_block_size = 66612, use_primary_key_cache = false, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:14:24.257804 [ 31788 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:14:24.404662 [ 12989 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:14:24.930266 [ 16784 ] {02e270db-1cb6-4212-a900-7eb4df057412} executeQuery: Code: 386. DB::Exception: There is no supertype for types String, Array(Nothing) because some of them are Array and some of them are not: In scope SELECT hasAny([['Hello, world']], [[[]]]). (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51752) (comment: 00918_has_unsufficient_type_check.sql) (query 1, line 1) (in query: SELECT hasAny([['Hello, world']], [[[]]]);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000dda78ab 4. /build/src/DataTypes/getLeastSupertype.cpp:69: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x0000000013b8f59e 5. /build/src/DataTypes/getLeastSupertype.cpp:355: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000013b92b1e 6. /build/src/DataTypes/getLeastSupertype.cpp:357: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000013b91781 7. /build/src/DataTypes/getLeastSupertype.cpp:357: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000013b91781 8. /build/src/Functions/array/hasAllAny.h:66: DB::FunctionArrayHasAllAny::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f6f2ffc 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:14:24.939279 [ 16784 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types String, Array(Nothing) because some of them are Array and some of them are not: In scope SELECT hasAny([['Hello, world']], [[[]]]). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000dda78ab 4. /build/src/DataTypes/getLeastSupertype.cpp:69: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x0000000013b8f59e 5. /build/src/DataTypes/getLeastSupertype.cpp:355: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000013b92b1e 6. /build/src/DataTypes/getLeastSupertype.cpp:357: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000013b91781 7. /build/src/DataTypes/getLeastSupertype.cpp:357: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000013b91781 8. /build/src/Functions/array/hasAllAny.h:66: DB::FunctionArrayHasAllAny::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f6f2ffc 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:14:25.490145 [ 4922 ] {b5f8b2e4-2756-4ec5-934f-19e4ff27c902} StorageBuffer (test_9.buffer_): Destination table test_9.null_ doesn't exist. Block of data is discarded. 2025.07.13 02:14:27.410812 [ 6608 ] {4c994e63-5ba0-4ef3-b3ed-00cd835ba5b4} 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]:51818) (comment: 02490_benchmark_max_consecutive_errors.sh) (in query: select throwIf(1)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e730315 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:14:27.449768 [ 6608 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e730315 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:14:27.933230 [ 16784 ] {f5ade48c-bff6-4ce2-bbe1-e6c23ee74c5f} 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]:51830) (comment: 02490_benchmark_max_consecutive_errors.sh) (in query: select throwIf(1)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e730315 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:14:27.965053 [ 16784 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e730315 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:14:28.269834 [ 31831 ] {4cd0a71b-acf9-41c0-b818-22f3f7ca6897} 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]:51832) (comment: 02490_benchmark_max_consecutive_errors.sh) (in query: select throwIf(1)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e730315 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:14:28.307758 [ 31831 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e730315 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:14:28.467080 [ 6619 ] {b7361de1-7e94-4925-9d66-63299a5367dd} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=853, jobs=821). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51794) (comment: 00725_comment_columns_long.sql) (query 6, line 20) (in query: SELECT table, name, comment FROM system.columns WHERE table = 'check_query_comment_column' AND database = currentDatabase() FORMAT PrettyCompactNoEscapes;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbdd1d3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd751c 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 9. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 10. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:14:28.517058 [ 6619 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=853, jobs=821). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbdd1d3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd751c 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 9. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 10. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:14:28.650260 [ 6608 ] {42424ab7-f0c0-4e61-a302-e4361b27ace8} 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]:51846) (comment: 02490_benchmark_max_consecutive_errors.sh) (in query: select throwIf(1)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e730315 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:14:28.663652 [ 6608 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e730315 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:14:28.883427 [ 3543 ] {71a0556d-b36d-43da-b0ed-e9b6f9ec379a} 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]:51856) (comment: 02490_benchmark_max_consecutive_errors.sh) (in query: select throwIf(1)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e730315 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:14:28.889730 [ 3543 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e730315 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:14:29.153578 [ 4922 ] {73191689-5a69-4ce3-aa72-5787d7a78d32} 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]:43722) (comment: 02490_benchmark_max_consecutive_errors.sh) (in query: select throwIf(1)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e730315 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:14:29.176904 [ 4922 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e730315 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:14:29.475828 [ 12986 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:14:29.512690 [ 3543 ] {09aca9f9-9bf5-4e8a-bc4b-c44076971f83} 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]:43732) (comment: 02490_benchmark_max_consecutive_errors.sh) (in query: select throwIf(1)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e730315 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:14:29.528325 [ 3543 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e730315 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:14:29.548946 [ 31831 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000013779f8b 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000137794b8 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778bc3 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678d325 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:14:29.738703 [ 4922 ] {24040373-2105-4890-8e2f-be0f0f336a6b} 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]:43754) (comment: 02490_benchmark_max_consecutive_errors.sh) (in query: select throwIf(1)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e730315 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:14:29.765655 [ 4922 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e730315 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:14:30.108335 [ 3543 ] {daac707f-04a8-4607-b152-0f3abbac9fe7} 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]:43778) (comment: 02490_benchmark_max_consecutive_errors.sh) (in query: select throwIf(1)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e730315 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:14:30.168900 [ 3543 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e730315 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:14:30.400555 [ 4922 ] {b2a342dc-e74a-4950-b7cf-ff73e59e8ed0} 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]:43794) (comment: 02490_benchmark_max_consecutive_errors.sh) (in query: select throwIf(1)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e730315 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:14:30.418325 [ 4922 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e730315 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:14:30.717812 [ 3543 ] {6779071a-389e-4f28-9452-6db45c9d5b57} 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]:43808) (comment: 02490_benchmark_max_consecutive_errors.sh) (in query: select throwIf(1)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e730315 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:14:30.725346 [ 3543 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e730315 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:14:34.436920 [ 11489 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:14:34.492257 [ 3726 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda7a6 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000118cbf6e 8. /build/src/Interpreters/DatabaseCatalog.cpp:1360: DB::DatabaseCatalog::dropTablesParallel(std::vector, std::allocator>>) @ 0x0000000014421059 9. /build/src/Interpreters/DatabaseCatalog.cpp:1382: DB::DatabaseCatalog::dropTableDataTask() @ 0x000000001442155c 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013882414 11. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000138854aa 12. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000013885c47 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 14. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:14:35.542404 [ 31831 ] {0770ddd1-1e2f-42e1-8d77-3eaf34a7eb07} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43816) (comment: 03368_bfloat16_merge_join.sql) (query 6, line 6) (in query: SELECT sum(t1d0.c0 != t2d0.c0) FROM t0 t0d0 JOIN t0 t1d0 ON t1d0.c0 = t0d0.c0 JOIN t0 t2d0 ON t1d0.c1 = t2d0.c1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda7a6 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbdb1ad 7. /build/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) @ 0x000000001631ac2d 8. /build/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) @ 0x0000000016d5067d 9. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x0000000016d4f5b9 10. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x0000000016d4f3b2 11. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d571cc 12. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016cf6870 13. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:14:35.591120 [ 31831 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda7a6 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbdb1ad 7. /build/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) @ 0x000000001631ac2d 8. /build/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) @ 0x0000000016d5067d 9. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x0000000016d4f5b9 10. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x0000000016d4f3b2 11. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d571cc 12. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016cf6870 13. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:14:36.893414 [ 6608 ] {c0a0be9d-bca5-4bcc-a134-acd3c7f5a3d2} executeQuery: Code: 43. DB::Exception: Argument 1 of function arrayZipUnaligned must be array. Found String instead.: In scope SELECT arrayZipUnaligned('a', 'b', 'c'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43850) (comment: 03230_array_zip_unaligned.sql) (query 4, line 7) (in query: SELECT arrayZipUnaligned('a', 'b', 'c');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/array/arrayZip.cpp:47: DB::FunctionArrayZip::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f694428 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:14:36.931659 [ 6608 ] {} TCPHandler: Code: 43. DB::Exception: Argument 1 of function arrayZipUnaligned must be array. Found String instead.: In scope SELECT arrayZipUnaligned('a', 'b', 'c'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Functions/array/arrayZip.cpp:47: DB::FunctionArrayZip::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f694428 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:14:38.072185 [ 16763 ] {11e64cf8-10e9-4dcf-926e-2295bd245df6} executeQuery: Code: 57. DB::Exception: Table test_7.t1 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43892) (comment: 03215_partition_in_tuple.sql) (query 2, line 9) (in query: CREATE TABLE t1 (`a` DateTime64(3), `b` FixedString(6)) ENGINE = MergeTree PARTITION BY toStartOfDay(a) ORDER BY (a, b) SETTINGS index_granularity = 65273, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 315142617, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 26560373, merge_max_block_size = 14943, old_parts_lifetime = 423., prefer_fetch_merged_part_size_threshold = 559771851, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 9773169627, index_granularity_bytes = 14050194, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 76, 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 = 87931, primary_key_compress_block_size = 93336, use_primary_key_cache = false, prewarm_primary_key_cache = true, prewarm_mark_cache = false AS SELECT '2023-01-01 00:00:00.000', 'fd4c03'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:14:38.093485 [ 16763 ] {} TCPHandler: Code: 57. DB::Exception: Table test_7.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:14:39.664753 [ 5077 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:14:40.193591 [ 16763 ] {e0347938-a8e7-4800-869e-6d6c0c0f02f6} PushingToViews: Failed to push block to view test_15.mview (3b5b4526-a7ed-4f19-a492-45c6854bc918), Unknown expression identifier `n` in scope SELECT n, n * n AS n2 FROM test_15.test_table 2025.07.13 02:14:40.359422 [ 16763 ] {e0347938-a8e7-4800-869e-6d6c0c0f02f6} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `n` in scope SELECT n, n * n AS n2 FROM test_15.test_table. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46886) (comment: 02374_analyzer_array_join.sql) (query 4, line 12) (in query: INSERT INTO test_table VALUES ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000013f69e39 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f3a889 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001489281b 14. /build/src/Processors/Transforms/buildPushingToViewsChain.cpp:352: DB::generateViewChain(std::shared_ptr, unsigned long, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x0000000016bd4539 15. /build/src/Processors/Transforms/buildPushingToViewsChain.cpp:530: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000016bd8431 16. /build/src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000001484c2eb 17. /build/src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000001484dcd2 18. /build/src/Interpreters/InterpreterInsertQuery.cpp:755: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000148509b4 19. /build/src/Interpreters/InterpreterInsertQuery.cpp:875: DB::InterpreterInsertQuery::execute() @ 0x0000000014852193 20. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:14:40.401725 [ 16763 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `n` in scope SELECT n, n * n AS n2 FROM test_15.test_table. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000013f69e39 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f3a889 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001489281b 14. /build/src/Processors/Transforms/buildPushingToViewsChain.cpp:352: DB::generateViewChain(std::shared_ptr, unsigned long, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x0000000016bd4539 15. /build/src/Processors/Transforms/buildPushingToViewsChain.cpp:530: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000016bd8431 16. /build/src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000001484c2eb 17. /build/src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000001484dcd2 18. /build/src/Interpreters/InterpreterInsertQuery.cpp:755: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000148509b4 19. /build/src/Interpreters/InterpreterInsertQuery.cpp:875: DB::InterpreterInsertQuery::execute() @ 0x0000000014852193 20. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:14:44.583775 [ 5071 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:14:46.142082 [ 16763 ] {02e0ad6f-8044-4f6e-9ecd-fa5201ff92fe} 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]:46962) (comment: 01471_top_k_range_check.sql) (query 1, line 1) (in query: SELECT length(topKWeighted(2, -9223372036854775808)(number, 1025)) FROM system.numbers;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/AggregateFunctions/AggregateFunctionTopK.cpp:506: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionTopK(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000001129f7e0 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130caa1d 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:14:46.157087 [ 16763 ] {} TCPHandler: Code: 69. DB::Exception: Too large parameter(s) for aggregate function 'topKWeighted' (maximum is 16777215). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/AggregateFunctions/AggregateFunctionTopK.cpp:506: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionTopK(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000001129f7e0 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130caa1d 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:14:48.714090 [ 27539 ] {56c1269a-186e-41d9-a7ec-58804046ba80} executeQuery: Code: 386. DB::Exception: There is no supertype for types Array(UInt8), Int8 because some of them are Array and some of them are not. (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46960) (comment: 02013_bloom_filter_hasAll.sql) (query 7, line 19) (in query: SELECT count() FROM bftest WHERE hasAll(y, [[123], -42]) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000dda78ab 4. /build/src/DataTypes/getLeastSupertype.cpp:69: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x0000000013b8f59e 5. /build/src/DataTypes/getLeastSupertype.cpp:355: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000013b92b1e 6. /build/src/DataTypes/FieldToDataType.cpp:170: DB::FieldToDataType<(DB::LeastSupertypeOnError)0>::operator()(DB::Array const&) const @ 0x0000000013b69274 7. /build/src/Common/FieldVisitors.h:24: DB::ConstantNode::ConstantNode(DB::Field) @ 0x0000000013e7feae 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::Field const&, 0>(std::allocator const&, DB::Field const&) @ 0x0000000013f1b0b6 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013f0bb47 10. /build/src/Analyzer/QueryTreeBuilder.cpp:701: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013f0c1f0 11. /build/src/Analyzer/QueryTreeBuilder.cpp:364: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013f0fbff 12. /build/src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013f0a8b1 13. /build/src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013f0d01d 14. /build/src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013f0a7bd 15. /build/src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x0000000013f0a42b 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014892440 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:14:48.752804 [ 27539 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Array(UInt8), Int8 because some of them are Array and some of them are not. (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000dda78ab 4. /build/src/DataTypes/getLeastSupertype.cpp:69: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x0000000013b8f59e 5. /build/src/DataTypes/getLeastSupertype.cpp:355: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000013b92b1e 6. /build/src/DataTypes/FieldToDataType.cpp:170: DB::FieldToDataType<(DB::LeastSupertypeOnError)0>::operator()(DB::Array const&) const @ 0x0000000013b69274 7. /build/src/Common/FieldVisitors.h:24: DB::ConstantNode::ConstantNode(DB::Field) @ 0x0000000013e7feae 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::Field const&, 0>(std::allocator const&, DB::Field const&) @ 0x0000000013f1b0b6 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013f0bb47 10. /build/src/Analyzer/QueryTreeBuilder.cpp:701: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013f0c1f0 11. /build/src/Analyzer/QueryTreeBuilder.cpp:364: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013f0fbff 12. /build/src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013f0a8b1 13. /build/src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013f0d01d 14. /build/src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013f0a7bd 15. /build/src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x0000000013f0a42b 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014892440 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:14:48.864515 [ 31799 ] {e06e2827-a763-420c-987f-5a78489a4eb6} Context: Server has databases (for example `ordinary_test_t3b940em`) 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:14:49.757783 [ 5991 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:14:51.260147 [ 27539 ] {300b03f9-717a-4ae9-b794-54bff578a459} executeQuery: Code: 277. DB::Exception: Index `ix1` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46960) (comment: 02013_bloom_filter_hasAll.sql) (query 14, line 28) (in query: -- can't use bloom_filter with `hasAll` on non-constant arguments (just like `has`) SELECT count() FROM bftest WHERE hasAll(x, materialize([1,2,3])) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/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) @ 0x000000001631c80f 5. /build/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) @ 0x0000000016d5067d 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x0000000016d4f5b9 7. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x0000000016d4f3b2 8. /build/src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:612: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x0000000016df9dfe 9. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:196: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1c92 10. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:14:51.270064 [ 27539 ] {} TCPHandler: Code: 277. DB::Exception: Index `ix1` 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/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) @ 0x000000001631c80f 5. /build/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) @ 0x0000000016d5067d 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x0000000016d4f5b9 7. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x0000000016d4f3b2 8. /build/src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:612: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x0000000016df9dfe 9. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:196: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1c92 10. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:14:51.495283 [ 27539 ] {c39c70fd-6a27-4761-a055-ebd9776307b5} executeQuery: Code: 277. DB::Exception: Index `ix1` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46960) (comment: 02013_bloom_filter_hasAll.sql) (query 15, line 31) (in query: -- NULLs are not Ok SELECT count() FROM bftest WHERE hasAll(x, [NULL,-42]) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/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) @ 0x000000001631c80f 5. /build/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) @ 0x0000000016d5067d 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x0000000016d4f5b9 7. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x0000000016d4f3b2 8. /build/src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:612: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x0000000016df9dfe 9. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:196: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1c92 10. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:14:51.537327 [ 27539 ] {} TCPHandler: Code: 277. DB::Exception: Index `ix1` 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/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) @ 0x000000001631c80f 5. /build/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) @ 0x0000000016d5067d 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x0000000016d4f5b9 7. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x0000000016d4f3b2 8. /build/src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:612: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x0000000016df9dfe 9. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:196: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1c92 10. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:14:51.757044 [ 27539 ] {67713bc6-998c-4959-a9dc-7510bdad080f} executeQuery: Code: 277. DB::Exception: Index `ix1` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46960) (comment: 02013_bloom_filter_hasAll.sql) (query 16, line 33) (in query: SELECT count() FROM bftest WHERE hasAll(x, [0,NULL]) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/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) @ 0x000000001631c80f 5. /build/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) @ 0x0000000016d5067d 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x0000000016d4f5b9 7. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x0000000016d4f3b2 8. /build/src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:612: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x0000000016df9dfe 9. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:196: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1c92 10. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:14:51.842935 [ 27539 ] {} TCPHandler: Code: 277. DB::Exception: Index `ix1` 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/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) @ 0x000000001631c80f 5. /build/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) @ 0x0000000016d5067d 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x0000000016d4f5b9 7. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x0000000016d4f3b2 8. /build/src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:612: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x0000000016df9dfe 9. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:196: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1c92 10. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:14:51.962782 [ 27539 ] {3f6a4220-e3bb-4a8e-8fa3-e3294a198e8e} executeQuery: Code: 386. DB::Exception: There is no supertype for types Array(UInt8), Int8 because some of them are Array and some of them are not. (NO_COMMON_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46960) (comment: 02013_bloom_filter_hasAll.sql) (query 17, line 35) (in query: -- non-compatible types SELECT count() FROM bftest WHERE hasAll(x, [[123], -42]) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000dda78ab 4. /build/src/DataTypes/getLeastSupertype.cpp:69: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x0000000013b8f59e 5. /build/src/DataTypes/getLeastSupertype.cpp:355: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000013b92b1e 6. /build/src/DataTypes/FieldToDataType.cpp:170: DB::FieldToDataType<(DB::LeastSupertypeOnError)0>::operator()(DB::Array const&) const @ 0x0000000013b69274 7. /build/src/Common/FieldVisitors.h:24: DB::ConstantNode::ConstantNode(DB::Field) @ 0x0000000013e7feae 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::Field const&, 0>(std::allocator const&, DB::Field const&) @ 0x0000000013f1b0b6 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013f0bb47 10. /build/src/Analyzer/QueryTreeBuilder.cpp:701: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013f0c1f0 11. /build/src/Analyzer/QueryTreeBuilder.cpp:364: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013f0fbff 12. /build/src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013f0a8b1 13. /build/src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013f0d01d 14. /build/src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013f0a7bd 15. /build/src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x0000000013f0a42b 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014892440 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:14:51.969517 [ 27539 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Array(UInt8), Int8 because some of them are Array and some of them are not. (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000dda78ab 4. /build/src/DataTypes/getLeastSupertype.cpp:69: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x0000000013b8f59e 5. /build/src/DataTypes/getLeastSupertype.cpp:355: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000013b92b1e 6. /build/src/DataTypes/FieldToDataType.cpp:170: DB::FieldToDataType<(DB::LeastSupertypeOnError)0>::operator()(DB::Array const&) const @ 0x0000000013b69274 7. /build/src/Common/FieldVisitors.h:24: DB::ConstantNode::ConstantNode(DB::Field) @ 0x0000000013e7feae 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::Field const&, 0>(std::allocator const&, DB::Field const&) @ 0x0000000013f1b0b6 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013f0bb47 10. /build/src/Analyzer/QueryTreeBuilder.cpp:701: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013f0c1f0 11. /build/src/Analyzer/QueryTreeBuilder.cpp:364: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013f0fbff 12. /build/src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013f0a8b1 13. /build/src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013f0d01d 14. /build/src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000013f0a7bd 15. /build/src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x0000000013f0a42b 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014892440 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:14:52.147584 [ 27539 ] {96a2df89-c287-4fbc-a974-4d5fd122f696} executeQuery: Code: 277. DB::Exception: Index `ix1` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46960) (comment: 02013_bloom_filter_hasAll.sql) (query 18, line 37) (in query: SELECT count() FROM bftest WHERE hasAll(x, [toDecimal32(123, 3), 2]) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/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) @ 0x000000001631c80f 5. /build/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) @ 0x0000000016d5067d 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x0000000016d4f5b9 7. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x0000000016d4f3b2 8. /build/src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:612: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x0000000016df9dfe 9. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:196: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1c92 10. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:14:52.165365 [ 27539 ] {} TCPHandler: Code: 277. DB::Exception: Index `ix1` 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/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) @ 0x000000001631c80f 5. /build/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) @ 0x0000000016d5067d 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x0000000016d4f5b9 7. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x0000000016d4f3b2 8. /build/src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:612: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x0000000016df9dfe 9. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:196: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1c92 10. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:14:53.979426 [ 16784 ] {99daec83-bbd0-4664-be39-a5e0c17ba288} 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:14:54.799356 [ 6027 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:14:55.399578 [ 4922 ] {8596ad25-ac2e-41a9-a694-f2763a866d6d} 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_7.data): While executing CustomSeparatedRowInputFormat: While executing File. (CANNOT_READ_ALL_DATA) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34996) (comment: 02130_parse_quoted_null.sh) (query 1, line 1) (in query: select * from file('test_7.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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/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 @ 0x0000000013bf84de 5. /build/src/DataTypes/Serializations/SerializationNullable.cpp:211: void DB::deserializeTextQuotedImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x0000000013bf5c73 6. /build/src/DataTypes/Serializations/SerializationNullable.cpp:544: DB::SerializationNullable::deserializeTextQuoted(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013bf457f 7. /build/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&) @ 0x00000000168427eb 8. /build/src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001696eb1b 9. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016940972 10. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 11. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 12. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 15. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 16. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 17. /build/src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000015cae3aa 18. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 19. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 20. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 21. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 22. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 23. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 24. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 25. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:14:55.427790 [ 4922 ] {} 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_7.data): While executing CustomSeparatedRowInputFormat: While executing File. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/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 @ 0x0000000013bf84de 5. /build/src/DataTypes/Serializations/SerializationNullable.cpp:211: void DB::deserializeTextQuotedImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x0000000013bf5c73 6. /build/src/DataTypes/Serializations/SerializationNullable.cpp:544: DB::SerializationNullable::deserializeTextQuoted(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013bf457f 7. /build/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&) @ 0x00000000168427eb 8. /build/src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001696eb1b 9. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016940972 10. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000168e5bd6 11. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 12. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 15. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 16. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 17. /build/src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000015cae3aa 18. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000168c2cfa 19. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 20. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 21. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 22. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 23. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 24. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 25. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:14:56.554726 [ 30811 ] {d7ba254f-c803-44f1-8812-46fb28bb3f70} executeQuery: Code: 1. DB::Exception: Qualified matcher arr.* found a non-compound expression [1, 2, 3] AS arr with type Array(UInt8). Expected a tuple or an array of tuples. In scope WITH [1, 2, 3] AS arr SELECT arr.*. (UNSUPPORTED_METHOD) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34876) (comment: 02677_analyzer_compound_expressions.sql) (query 19, line 40) (in query: WITH [1, 2, 3] AS arr SELECT arr.*;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x000000000a04526b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1837: DB::QueryAnalyzer::resolveQualifiedMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4cd1b 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2204: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5a3b1 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3800: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38d68 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 11. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 12. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 17. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 19. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 20. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 2025.07.13 02:14:56.583186 [ 30811 ] {} TCPHandler: Code: 1. DB::Exception: Qualified matcher arr.* found a non-compound expression [1, 2, 3] AS arr with type Array(UInt8). Expected a tuple or an array of tuples. In scope WITH [1, 2, 3] AS arr SELECT arr.*. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x000000000a04526b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1837: DB::QueryAnalyzer::resolveQualifiedMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4cd1b 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2204: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5a3b1 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3800: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38d68 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 11. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 12. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 17. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 19. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 20. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 2025.07.13 02:14:56.895841 [ 30811 ] {18b31ec3-2a31-4288-9973-c34431ccd346} executeQuery: Code: 44. DB::Exception: The second argument of function getSubcolumn should be a constant string with the name of a subcolumn: In scope SELECT getSubcolumn([1, 2, 3], materialize('size0')). (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34876) (comment: 02677_analyzer_compound_expressions.sql) (query 21, line 43) (in query: SELECT getSubcolumn([1, 2, 3], materialize('size0'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000009fd7e2b 4. /build/src/Functions/getSubcolumn.cpp:48: DB::(anonymous namespace)::FunctionGetSubcolumn::getSubcolumnName(std::vector> const&) @ 0x000000000b97d74a 5. /build/src/Functions/getSubcolumn.cpp:33: DB::(anonymous namespace)::FunctionGetSubcolumn::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b97d60c 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80f9b 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:14:56.902636 [ 30811 ] {} TCPHandler: Code: 44. DB::Exception: The second argument of function getSubcolumn should be a constant string with the name of a subcolumn: In scope SELECT getSubcolumn([1, 2, 3], materialize('size0')). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000009fd7e2b 4. /build/src/Functions/getSubcolumn.cpp:48: DB::(anonymous namespace)::FunctionGetSubcolumn::getSubcolumnName(std::vector> const&) @ 0x000000000b97d74a 5. /build/src/Functions/getSubcolumn.cpp:33: DB::(anonymous namespace)::FunctionGetSubcolumn::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b97d60c 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80f9b 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:14:57.122784 [ 30811 ] {021f1f94-60c9-4d27-9f64-6802eb4f7647} executeQuery: Code: 44. DB::Exception: There is no subcolumn aaa in type Array(UInt8): In scope SELECT getSubcolumn([1, 2, 3], 'aaa'). (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34876) (comment: 02677_analyzer_compound_expressions.sql) (query 22, line 44) (in query: SELECT getSubcolumn([1, 2, 3], 'aaa');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000013779f8b 4. /build/src/DataTypes/IDataType.cpp:176: DB::IDataType::getSubcolumnData(std::basic_string_view>, DB::ISerialization::SubstreamData const&, bool) @ 0x0000000013b6c62f 5. /build/src/DataTypes/IDataType.cpp:211: DB::IDataType::getSubcolumnType(std::basic_string_view>) const @ 0x0000000013b6cd79 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80f9b 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:14:57.197429 [ 30811 ] {} TCPHandler: Code: 44. DB::Exception: There is no subcolumn aaa in type Array(UInt8): In scope SELECT getSubcolumn([1, 2, 3], 'aaa'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000013779f8b 4. /build/src/DataTypes/IDataType.cpp:176: DB::IDataType::getSubcolumnData(std::basic_string_view>, DB::ISerialization::SubstreamData const&, bool) @ 0x0000000013b6c62f 5. /build/src/DataTypes/IDataType.cpp:211: DB::IDataType::getSubcolumnType(std::basic_string_view>) const @ 0x0000000013b6cd79 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80f9b 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:14:57.929617 [ 16784 ] {f915c24e-2119-4f2c-a856-ead5333ebf00} 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]:34938) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Storages/StorageMergeTree.cpp:2756: DB::StorageMergeTree::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000016559e13 5. /build/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&) @ 0x0000000016bd98a4 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000001484c2eb 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000001484dcd2 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:755: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000148509b4 9. /build/src/Interpreters/InterpreterInsertQuery.cpp:875: DB::InterpreterInsertQuery::execute() @ 0x0000000014852193 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:14:57.945877 [ 16784 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Storages/StorageMergeTree.cpp:2756: DB::StorageMergeTree::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000016559e13 5. /build/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&) @ 0x0000000016bd98a4 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000001484c2eb 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000001484dcd2 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:755: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000148509b4 9. /build/src/Interpreters/InterpreterInsertQuery.cpp:875: DB::InterpreterInsertQuery::execute() @ 0x0000000014852193 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:14:58.072103 [ 16784 ] {fdc3d8e0-eea2-4936-9357-41026f2aa85e} 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]:34938) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Storages/StorageMergeTree.cpp:2756: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000001656c88a 5. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014bf58ce 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:14:58.093138 [ 16784 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Storages/StorageMergeTree.cpp:2756: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000001656c88a 5. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014bf58ce 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:14:59.715823 [ 11497 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:15:00.996736 [ 5998 ] {01670195-f9c2-4795-8767-8a41f838bf67} 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]:34846) (comment: 02870_per_column_settings.sql) (query 20, line 46) (in query: SET allow_experimental_object_type = 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:15:01.023822 [ 5998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:15:01.816111 [ 6612 ] {41379afe-0086-423b-b543-87be4d27a6c3} 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]:39962) (comment: 02127_storage_join_settings_with_persistency.sql) (in query: DROP DATABASE IF EXISTS test_lmam6rda SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:15:01.820205 [ 6612 ] {41379afe-0086-423b-b543-87be4d27a6c3} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:15:01.902389 [ 31788 ] {176cdd66-45f0-4ca9-a3ec-a0d33f3c7d65} executeQuery: Code: 215. DB::Exception: Column r.a is not under aggregate function and not in GROUP BY keys. In query SELECT v.x, r.a, sum(c) FROM (SELECT 1 AS x, 2 AS c) AS v ANY LEFT JOIN (SELECT 1 AS x, 2 AS a) AS r ON v.x = r.x GROUP BY v.x. (NOT_AN_AGGREGATE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37320) (comment: 03126_column_not_under_group_by.sql) (query 2, line 3) (in query: SELECT v.x, r.a, sum(c) FROM (select 1 x, 2 c) AS v ANY LEFT JOIN (SELECT 1 x, 2 a) AS r ON v.x = r.x GROUP BY v.x;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Analyzer/ValidationUtils.cpp:199: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000013f86ce9 5. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000013f86917 6. /build/src/Analyzer/ValidationUtils.cpp:359: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000013f85f8a 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f332a5 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:15:01.912219 [ 31788 ] {} TCPHandler: Code: 215. DB::Exception: Column r.a is not under aggregate function and not in GROUP BY keys. In query SELECT v.x, r.a, sum(c) FROM (SELECT 1 AS x, 2 AS c) AS v ANY LEFT JOIN (SELECT 1 AS x, 2 AS a) AS r ON v.x = r.x GROUP BY v.x. (NOT_AN_AGGREGATE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Analyzer/ValidationUtils.cpp:199: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000013f86ce9 5. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000013f86917 6. /build/src/Analyzer/ValidationUtils.cpp:359: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000013f85f8a 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f332a5 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:15:02.665838 [ 27693 ] {e31e7d1a-cadf-42f2-afc5-048fd251558a} executeQuery: Code: 36. DB::Exception: JOIN INNER JOIN ... USING (id, id, id) identifier 'id' appears more than once in USING clause. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35082) (comment: 02382_analyzer_matcher_join_using.sql) (query 18, line 40) (in query: SELECT * FROM test_table_join_1 AS t1 INNER JOIN test_table_join_2 AS t2 USING (id, id, id) ORDER BY id, t1.value;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a59c08b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5168: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f66f97 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 9. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 14. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 15. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 16. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 17. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 22. ? @ 0x00007f7210eb6ac3 23. ? @ 0x00007f7210f48850 2025.07.13 02:15:02.693558 [ 27693 ] {} TCPHandler: Code: 36. DB::Exception: JOIN INNER JOIN ... USING (id, id, id) identifier 'id' appears more than once in USING clause. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a59c08b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5168: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f66f97 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 9. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 14. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 15. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 16. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 17. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 22. ? @ 0x00007f7210eb6ac3 23. ? @ 0x00007f7210f48850 2025.07.13 02:15:04.843656 [ 4922 ] {78e7a28d-0b9f-43fd-8de1-c415000ff5cf} executeQuery: Code: 36. DB::Exception: ALTER UPDATE/ALTER DELETE statements with nondeterministic deterministic functions cannot be applied on fly. Function 'rand' is non-deterministic. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37346) (comment: 03047_on_fly_mutations_non_deterministic.sql) (query 7, line 12) (in query: SELECT * FROM t_lightweight_mut_2;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Storages/MergeTree/AlterConversions.cpp:99: DB::AlterConversions::addMutationCommand(DB::MutationCommand const&) @ 0x00000000162cfd35 5. /build/src/Storages/MergeTree/MergeTreeData.cpp:8667: DB::MergeTreeData::getAlterConversionsForPart(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000162a42a9 6. /build/src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:156: DB::MergeTreeReadPoolBase::fillPerPartInfos(DB::Settings const&) @ 0x0000000016d761a7 7. /build/src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:51: DB::MergeTreeReadPoolBase::MergeTreeReadPoolBase(DB::RangesInDataParts&&, std::shared_ptr, std::unordered_map, std::equal_to, std::allocator>>, std::shared_ptr const&, std::shared_ptr const&, DB::ExpressionActionsSettings const&, DB::MergeTreeReaderSettings const&, std::vector> const&, DB::MergeTreeReadPoolBase::PoolSettings const&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr const&) @ 0x0000000016d75bab 8. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:25: DB::MergeTreeReadPoolInOrder::MergeTreeReadPoolInOrder(bool, DB::MergeTreeReadType, DB::RangesInDataParts, std::shared_ptr, std::unordered_map, std::equal_to, std::allocator>>, std::shared_ptr const&, std::shared_ptr const&, DB::ExpressionActionsSettings const&, DB::MergeTreeReaderSettings const&, std::vector> const&, DB::MergeTreeReadPoolBase::PoolSettings const&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr const&) @ 0x0000000016d9c839 9. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeReadPoolInOrder* std::construct_at[abi:se190107]&, std::unordered_map, std::equal_to, std::allocator>>&, std::shared_ptr&, std::shared_ptr&, DB::ExpressionActionsSettings&, DB::MergeTreeReaderSettings&, std::vector>&, DB::MergeTreeReadPoolBase::PoolSettings&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr&, DB::MergeTreeReadPoolInOrder*>(DB::MergeTreeReadPoolInOrder*, bool&, DB::MergeTreeReadType&, DB::RangesInDataParts&, std::shared_ptr&, std::unordered_map, std::equal_to, std::allocator>>&, std::shared_ptr&, std::shared_ptr&, DB::ExpressionActionsSettings&, DB::MergeTreeReaderSettings&, std::vector>&, DB::MergeTreeReadPoolBase::PoolSettings&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr&) @ 0x0000000016d673a5 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::ReadFromMergeTree::readInOrder(DB::RangesInDataParts, std::vector>, DB::MergeTreeReadPoolBase::PoolSettings, DB::MergeTreeReadType, unsigned long) @ 0x0000000016d43e75 11. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:737: DB::ReadFromMergeTree::read(DB::RangesInDataParts, std::vector>, DB::MergeTreeReadType, unsigned long, unsigned long, bool) @ 0x0000000016d45a80 12. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:938: DB::ReadFromMergeTree::spreadMarkRangesAmongStreams(DB::RangesInDataParts&&, unsigned long, std::vector> const&) @ 0x0000000016d4663f 13. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2066: DB::ReadFromMergeTree::spreadMarkRanges(DB::RangesInDataParts&&, unsigned long, DB::ReadFromMergeTree::AnalysisResult&, std::optional&) @ 0x0000000016d55f95 14. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2164: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d5781f 15. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016cf6870 16. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 19. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:15:04.847497 [ 5086 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:15:04.853851 [ 4922 ] {} TCPHandler: Code: 36. DB::Exception: ALTER UPDATE/ALTER DELETE statements with nondeterministic deterministic functions cannot be applied on fly. Function 'rand' is non-deterministic. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Storages/MergeTree/AlterConversions.cpp:99: DB::AlterConversions::addMutationCommand(DB::MutationCommand const&) @ 0x00000000162cfd35 5. /build/src/Storages/MergeTree/MergeTreeData.cpp:8667: DB::MergeTreeData::getAlterConversionsForPart(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000162a42a9 6. /build/src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:156: DB::MergeTreeReadPoolBase::fillPerPartInfos(DB::Settings const&) @ 0x0000000016d761a7 7. /build/src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:51: DB::MergeTreeReadPoolBase::MergeTreeReadPoolBase(DB::RangesInDataParts&&, std::shared_ptr, std::unordered_map, std::equal_to, std::allocator>>, std::shared_ptr const&, std::shared_ptr const&, DB::ExpressionActionsSettings const&, DB::MergeTreeReaderSettings const&, std::vector> const&, DB::MergeTreeReadPoolBase::PoolSettings const&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr const&) @ 0x0000000016d75bab 8. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:25: DB::MergeTreeReadPoolInOrder::MergeTreeReadPoolInOrder(bool, DB::MergeTreeReadType, DB::RangesInDataParts, std::shared_ptr, std::unordered_map, std::equal_to, std::allocator>>, std::shared_ptr const&, std::shared_ptr const&, DB::ExpressionActionsSettings const&, DB::MergeTreeReaderSettings const&, std::vector> const&, DB::MergeTreeReadPoolBase::PoolSettings const&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr const&) @ 0x0000000016d9c839 9. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeReadPoolInOrder* std::construct_at[abi:se190107]&, std::unordered_map, std::equal_to, std::allocator>>&, std::shared_ptr&, std::shared_ptr&, DB::ExpressionActionsSettings&, DB::MergeTreeReaderSettings&, std::vector>&, DB::MergeTreeReadPoolBase::PoolSettings&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr&, DB::MergeTreeReadPoolInOrder*>(DB::MergeTreeReadPoolInOrder*, bool&, DB::MergeTreeReadType&, DB::RangesInDataParts&, std::shared_ptr&, std::unordered_map, std::equal_to, std::allocator>>&, std::shared_ptr&, std::shared_ptr&, DB::ExpressionActionsSettings&, DB::MergeTreeReaderSettings&, std::vector>&, DB::MergeTreeReadPoolBase::PoolSettings&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr&) @ 0x0000000016d673a5 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::ReadFromMergeTree::readInOrder(DB::RangesInDataParts, std::vector>, DB::MergeTreeReadPoolBase::PoolSettings, DB::MergeTreeReadType, unsigned long) @ 0x0000000016d43e75 11. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:737: DB::ReadFromMergeTree::read(DB::RangesInDataParts, std::vector>, DB::MergeTreeReadType, unsigned long, unsigned long, bool) @ 0x0000000016d45a80 12. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:938: DB::ReadFromMergeTree::spreadMarkRangesAmongStreams(DB::RangesInDataParts&&, unsigned long, std::vector> const&) @ 0x0000000016d4663f 13. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2066: DB::ReadFromMergeTree::spreadMarkRanges(DB::RangesInDataParts&&, unsigned long, DB::ReadFromMergeTree::AnalysisResult&, std::optional&) @ 0x0000000016d55f95 14. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2164: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d5781f 15. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016cf6870 16. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 19. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:15:07.142643 [ 4922 ] {a7b69237-74c8-4a14-8197-27518a22c4bd} executeQuery: Code: 36. DB::Exception: ALTER UPDATE/ALTER DELETE statement with subquery may be nondeterministic and cannot be applied on fly. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37346) (comment: 03047_on_fly_mutations_non_deterministic.sql) (query 13, line 21) (in query: SELECT * FROM t_lightweight_mut_2;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Storages/MergeTree/AlterConversions.cpp:95: DB::AlterConversions::addMutationCommand(DB::MutationCommand const&) @ 0x00000000162cfcc7 5. /build/src/Storages/MergeTree/MergeTreeData.cpp:8667: DB::MergeTreeData::getAlterConversionsForPart(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000162a42a9 6. /build/src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:156: DB::MergeTreeReadPoolBase::fillPerPartInfos(DB::Settings const&) @ 0x0000000016d761a7 7. /build/src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:51: DB::MergeTreeReadPoolBase::MergeTreeReadPoolBase(DB::RangesInDataParts&&, std::shared_ptr, std::unordered_map, std::equal_to, std::allocator>>, std::shared_ptr const&, std::shared_ptr const&, DB::ExpressionActionsSettings const&, DB::MergeTreeReaderSettings const&, std::vector> const&, DB::MergeTreeReadPoolBase::PoolSettings const&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr const&) @ 0x0000000016d75bab 8. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:25: DB::MergeTreeReadPoolInOrder::MergeTreeReadPoolInOrder(bool, DB::MergeTreeReadType, DB::RangesInDataParts, std::shared_ptr, std::unordered_map, std::equal_to, std::allocator>>, std::shared_ptr const&, std::shared_ptr const&, DB::ExpressionActionsSettings const&, DB::MergeTreeReaderSettings const&, std::vector> const&, DB::MergeTreeReadPoolBase::PoolSettings const&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr const&) @ 0x0000000016d9c839 9. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeReadPoolInOrder* std::construct_at[abi:se190107]&, std::unordered_map, std::equal_to, std::allocator>>&, std::shared_ptr&, std::shared_ptr&, DB::ExpressionActionsSettings&, DB::MergeTreeReaderSettings&, std::vector>&, DB::MergeTreeReadPoolBase::PoolSettings&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr&, DB::MergeTreeReadPoolInOrder*>(DB::MergeTreeReadPoolInOrder*, bool&, DB::MergeTreeReadType&, DB::RangesInDataParts&, std::shared_ptr&, std::unordered_map, std::equal_to, std::allocator>>&, std::shared_ptr&, std::shared_ptr&, DB::ExpressionActionsSettings&, DB::MergeTreeReaderSettings&, std::vector>&, DB::MergeTreeReadPoolBase::PoolSettings&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr&) @ 0x0000000016d673a5 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::ReadFromMergeTree::readInOrder(DB::RangesInDataParts, std::vector>, DB::MergeTreeReadPoolBase::PoolSettings, DB::MergeTreeReadType, unsigned long) @ 0x0000000016d43e75 11. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:737: DB::ReadFromMergeTree::read(DB::RangesInDataParts, std::vector>, DB::MergeTreeReadType, unsigned long, unsigned long, bool) @ 0x0000000016d45a80 12. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:938: DB::ReadFromMergeTree::spreadMarkRangesAmongStreams(DB::RangesInDataParts&&, unsigned long, std::vector> const&) @ 0x0000000016d4663f 13. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2066: DB::ReadFromMergeTree::spreadMarkRanges(DB::RangesInDataParts&&, unsigned long, DB::ReadFromMergeTree::AnalysisResult&, std::optional&) @ 0x0000000016d55f95 14. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2164: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d5781f 15. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016cf6870 16. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 19. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:15:07.152238 [ 4922 ] {} TCPHandler: Code: 36. DB::Exception: ALTER UPDATE/ALTER DELETE statement with subquery may be nondeterministic and cannot be applied on fly. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Storages/MergeTree/AlterConversions.cpp:95: DB::AlterConversions::addMutationCommand(DB::MutationCommand const&) @ 0x00000000162cfcc7 5. /build/src/Storages/MergeTree/MergeTreeData.cpp:8667: DB::MergeTreeData::getAlterConversionsForPart(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000162a42a9 6. /build/src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:156: DB::MergeTreeReadPoolBase::fillPerPartInfos(DB::Settings const&) @ 0x0000000016d761a7 7. /build/src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:51: DB::MergeTreeReadPoolBase::MergeTreeReadPoolBase(DB::RangesInDataParts&&, std::shared_ptr, std::unordered_map, std::equal_to, std::allocator>>, std::shared_ptr const&, std::shared_ptr const&, DB::ExpressionActionsSettings const&, DB::MergeTreeReaderSettings const&, std::vector> const&, DB::MergeTreeReadPoolBase::PoolSettings const&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr const&) @ 0x0000000016d75bab 8. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:25: DB::MergeTreeReadPoolInOrder::MergeTreeReadPoolInOrder(bool, DB::MergeTreeReadType, DB::RangesInDataParts, std::shared_ptr, std::unordered_map, std::equal_to, std::allocator>>, std::shared_ptr const&, std::shared_ptr const&, DB::ExpressionActionsSettings const&, DB::MergeTreeReaderSettings const&, std::vector> const&, DB::MergeTreeReadPoolBase::PoolSettings const&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr const&) @ 0x0000000016d9c839 9. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeReadPoolInOrder* std::construct_at[abi:se190107]&, std::unordered_map, std::equal_to, std::allocator>>&, std::shared_ptr&, std::shared_ptr&, DB::ExpressionActionsSettings&, DB::MergeTreeReaderSettings&, std::vector>&, DB::MergeTreeReadPoolBase::PoolSettings&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr&, DB::MergeTreeReadPoolInOrder*>(DB::MergeTreeReadPoolInOrder*, bool&, DB::MergeTreeReadType&, DB::RangesInDataParts&, std::shared_ptr&, std::unordered_map, std::equal_to, std::allocator>>&, std::shared_ptr&, std::shared_ptr&, DB::ExpressionActionsSettings&, DB::MergeTreeReaderSettings&, std::vector>&, DB::MergeTreeReadPoolBase::PoolSettings&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr&) @ 0x0000000016d673a5 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::ReadFromMergeTree::readInOrder(DB::RangesInDataParts, std::vector>, DB::MergeTreeReadPoolBase::PoolSettings, DB::MergeTreeReadType, unsigned long) @ 0x0000000016d43e75 11. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:737: DB::ReadFromMergeTree::read(DB::RangesInDataParts, std::vector>, DB::MergeTreeReadType, unsigned long, unsigned long, bool) @ 0x0000000016d45a80 12. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:938: DB::ReadFromMergeTree::spreadMarkRangesAmongStreams(DB::RangesInDataParts&&, unsigned long, std::vector> const&) @ 0x0000000016d4663f 13. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2066: DB::ReadFromMergeTree::spreadMarkRanges(DB::RangesInDataParts&&, unsigned long, DB::ReadFromMergeTree::AnalysisResult&, std::optional&) @ 0x0000000016d55f95 14. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2164: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d5781f 15. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016cf6870 16. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 19. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:15:09.610545 [ 16758 ] {ca63424b-cf8c-4311-b798-2a8edbbb16fe} executeQuery: Code: 524. DB::Exception: ALTER of key column enum_key from type Enum8('y' = 1, 'x' = 2, 'z' = 3) to type Enum16('y' = 1, 'x' = 2, 'z' = 3) is not safe because it can change the representation of primary key. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37444) (comment: 01611_string_to_low_cardinality_key_alter.sql) (query 10, line 24) (in query: ALTER TABLE table_with_lc_key MODIFY COLUMN enum_key Enum16('x' = 2, 'y' = 1, 'z' = 3);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3832: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001625c911 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd033 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:15:09.621643 [ 16758 ] {} TCPHandler: Code: 524. DB::Exception: ALTER of key column enum_key from type Enum8('y' = 1, 'x' = 2, 'z' = 3) to type Enum16('y' = 1, 'x' = 2, 'z' = 3) is not safe because it can change the representation of primary key. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3832: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001625c911 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd033 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:15:09.779031 [ 5086 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:15:13.682781 [ 3543 ] {ef902cea-5681-4bde-ad38-fca8a09a71f9} executeQuery: Code: 36. DB::Exception: Dictionary (`test_9.dict1`) not found: In scope SELECT dictGetUInt8(concat('test_9', '.dict1'), 'second_column', toUInt64(11)). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52898) (comment: 01018_ddl_dictionaries_select.sql) (query 14, line 41) (in query: SELECT dictGetUInt8(concat('test_9', '.dict1'), 'second_column', toUInt64(11))), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Interpreters/ExternalDictionariesLoader.cpp:168: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x00000000147cba28 5. /build/src/Interpreters/ExternalDictionariesLoader.cpp:113: DB::ExternalDictionariesLoader::getDictionaryStructure(String const&, std::shared_ptr) const @ 0x00000000147cbec4 6. /build/src/Functions/FunctionsExternalDictionaries.h:138: DB::FunctionDictHelper::getDictionaryStructure(String const&) const @ 0x000000000a1177ad 7. /build/src/Functions/FunctionsExternalDictionaries.h:375: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a1139b8 8. /build/src/Functions/FunctionsExternalDictionaries.h:823: DB::FunctionDictGetImpl, DB::NameDictGetUInt8, (DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a123bef 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:15:13.692450 [ 3543 ] {} TCPHandler: Code: 36. DB::Exception: Dictionary (`test_9.dict1`) not found: In scope SELECT dictGetUInt8(concat('test_9', '.dict1'), 'second_column', toUInt64(11)). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Interpreters/ExternalDictionariesLoader.cpp:168: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x00000000147cba28 5. /build/src/Interpreters/ExternalDictionariesLoader.cpp:113: DB::ExternalDictionariesLoader::getDictionaryStructure(String const&, std::shared_ptr) const @ 0x00000000147cbec4 6. /build/src/Functions/FunctionsExternalDictionaries.h:138: DB::FunctionDictHelper::getDictionaryStructure(String const&) const @ 0x000000000a1177ad 7. /build/src/Functions/FunctionsExternalDictionaries.h:375: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a1139b8 8. /build/src/Functions/FunctionsExternalDictionaries.h:823: DB::FunctionDictGetImpl, DB::NameDictGetUInt8, (DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a123bef 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:15:14.366258 [ 16758 ] {24bd1636-2286-4820-982e-582a95836950} executeQuery: Code: 524. DB::Exception: ALTER of key column int_key from type Int8 to type Enum8('y' = 1, 'x' = 2) is not safe because it can change the representation of primary key. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37444) (comment: 01611_string_to_low_cardinality_key_alter.sql) (query 29, line 65) (in query: ALTER TABLE table_with_string_key MODIFY COLUMN int_key Enum8('y' = 1, 'x' = 2);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3832: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001625c911 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd033 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:15:14.387020 [ 16758 ] {} TCPHandler: Code: 524. DB::Exception: ALTER of key column int_key from type Int8 to type Enum8('y' = 1, 'x' = 2) is not safe because it can change the representation of primary key. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3832: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001625c911 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd033 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:15:14.987662 [ 3543 ] {5240466a-f142-4869-8d35-78d61d67132d} executeQuery: Code: 36. DB::Exception: Dictionary (`test_9.dict1`) not found: In scope SELECT dictGetUInt8(concat('test_9', '.dict1'), 'second_column', toUInt64(11)). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52898) (comment: 01018_ddl_dictionaries_select.sql) (query 18, line 49) (in query: SELECT dictGetUInt8(concat('test_9', '.dict1'), 'second_column', toUInt64(11))), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Interpreters/ExternalDictionariesLoader.cpp:168: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x00000000147cba28 5. /build/src/Interpreters/ExternalDictionariesLoader.cpp:113: DB::ExternalDictionariesLoader::getDictionaryStructure(String const&, std::shared_ptr) const @ 0x00000000147cbec4 6. /build/src/Functions/FunctionsExternalDictionaries.h:138: DB::FunctionDictHelper::getDictionaryStructure(String const&) const @ 0x000000000a1177ad 7. /build/src/Functions/FunctionsExternalDictionaries.h:375: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a1139b8 8. /build/src/Functions/FunctionsExternalDictionaries.h:823: DB::FunctionDictGetImpl, DB::NameDictGetUInt8, (DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a123bef 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:15:15.039982 [ 3543 ] {} TCPHandler: Code: 36. DB::Exception: Dictionary (`test_9.dict1`) not found: In scope SELECT dictGetUInt8(concat('test_9', '.dict1'), 'second_column', toUInt64(11)). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Interpreters/ExternalDictionariesLoader.cpp:168: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x00000000147cba28 5. /build/src/Interpreters/ExternalDictionariesLoader.cpp:113: DB::ExternalDictionariesLoader::getDictionaryStructure(String const&, std::shared_ptr) const @ 0x00000000147cbec4 6. /build/src/Functions/FunctionsExternalDictionaries.h:138: DB::FunctionDictHelper::getDictionaryStructure(String const&) const @ 0x000000000a1177ad 7. /build/src/Functions/FunctionsExternalDictionaries.h:375: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a1139b8 8. /build/src/Functions/FunctionsExternalDictionaries.h:823: DB::FunctionDictGetImpl, DB::NameDictGetUInt8, (DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a123bef 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:15:15.086553 [ 5085 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:15:15.295995 [ 27539 ] {9f7df633-5809-4a84-876d-d8ec1a58497c} executeQuery: Code: 153. DB::Exception: Division by zero: In scope SELECT divideDecimal(toDecimal64(123.123, 3), toDecimal64(0, 1)). (ILLEGAL_DIVISION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52976) (comment: 02475_precise_decimal_arithmetics.sql) (query 2, line 5) (in query: SELECT divideDecimal(toDecimal64(123.123, 3), toDecimal64(0, 1));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/divideDecimal.cpp:26: DB::Decimal> DB::(anonymous namespace)::DivideDecimalsImpl::execute, DB::Decimal>(DB::Decimal, DB::Decimal, unsigned short, unsigned short, unsigned short) @ 0x000000000b5208f1 5. /build/src/Functions/FunctionsDecimalArithmetics.h:172: void DB::Processor>>, DB::(anonymous namespace)::DivideDecimalsImpl>::vectorVector, 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 short, unsigned short, unsigned short, unsigned long) const @ 0x000000000b5200b0 6. /build/src/Functions/FunctionsDecimalArithmetics.h:219: DB::FunctionsDecimalArithmetics::resolveOverload(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b5197ce 7. /build/src/Functions/FunctionsDecimalArithmetics.h:298: DB::FunctionsDecimalArithmetics::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b517012 8. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 9. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 29. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 30. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 2025.07.13 02:15:15.322194 [ 27539 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: In scope SELECT divideDecimal(toDecimal64(123.123, 3), toDecimal64(0, 1)). (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/divideDecimal.cpp:26: DB::Decimal> DB::(anonymous namespace)::DivideDecimalsImpl::execute, DB::Decimal>(DB::Decimal, DB::Decimal, unsigned short, unsigned short, unsigned short) @ 0x000000000b5208f1 5. /build/src/Functions/FunctionsDecimalArithmetics.h:172: void DB::Processor>>, DB::(anonymous namespace)::DivideDecimalsImpl>::vectorVector, 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 short, unsigned short, unsigned short, unsigned long) const @ 0x000000000b5200b0 6. /build/src/Functions/FunctionsDecimalArithmetics.h:219: DB::FunctionsDecimalArithmetics::resolveOverload(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b5197ce 7. /build/src/Functions/FunctionsDecimalArithmetics.h:298: DB::FunctionsDecimalArithmetics::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b517012 8. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 9. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 29. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 30. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 2025.07.13 02:15:16.570825 [ 27539 ] {bfcc723e-afce-47db-b105-b466f0bfbca6} executeQuery: Code: 407. DB::Exception: Numeric overflow: result bigger that Decimal256: In scope SELECT multiplyDecimal(toDecimal256(1e38, 0), toDecimal256(1e38, 0), 2). (DECIMAL_OVERFLOW) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52976) (comment: 02475_precise_decimal_arithmetics.sql) (query 7, line 13) (in query: -- fits Decimal256, but scale is too big to fit SELECT multiplyDecimal(toDecimal256(1e38, 0), toDecimal256(1e38, 0), 2);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/multiplyDecimal.cpp:52: DB::Decimal> DB::(anonymous namespace)::MultiplyDecimalsImpl::execute>, DB::Decimal>>(DB::Decimal>, DB::Decimal>, unsigned short, unsigned short, unsigned short) @ 0x000000000da2a2c6 5. /build/src/Functions/FunctionsDecimalArithmetics.h:172: void DB::Processor>>, DB::(anonymous namespace)::MultiplyDecimalsImpl>::vectorVector>, 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 short, unsigned short, unsigned short, unsigned long) const @ 0x000000000da29803 6. /build/src/Functions/FunctionsDecimalArithmetics.h:219: DB::DecimalArithmeticsImpl>>, DB::DataTypeDecimal>>, DB::DataTypeDecimal>>, DB::(anonymous namespace)::MultiplyDecimalsImpl>::execute(DB::(anonymous namespace)::MultiplyDecimalsImpl, std::vector> const&, std::shared_ptr const&, unsigned long) @ 0x000000000da1dc86 7. /build/src/Functions/FunctionsDecimalArithmetics.h:368: DB::FunctionsDecimalArithmetics::resolveOverload(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000da198c4 8. /build/src/Functions/FunctionsDecimalArithmetics.h:298: DB::FunctionsDecimalArithmetics::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000da18b52 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:15:16.642417 [ 27539 ] {} TCPHandler: Code: 407. DB::Exception: Numeric overflow: result bigger that Decimal256: In scope SELECT multiplyDecimal(toDecimal256(1e38, 0), toDecimal256(1e38, 0), 2). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/multiplyDecimal.cpp:52: DB::Decimal> DB::(anonymous namespace)::MultiplyDecimalsImpl::execute>, DB::Decimal>>(DB::Decimal>, DB::Decimal>, unsigned short, unsigned short, unsigned short) @ 0x000000000da2a2c6 5. /build/src/Functions/FunctionsDecimalArithmetics.h:172: void DB::Processor>>, DB::(anonymous namespace)::MultiplyDecimalsImpl>::vectorVector>, 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 short, unsigned short, unsigned short, unsigned long) const @ 0x000000000da29803 6. /build/src/Functions/FunctionsDecimalArithmetics.h:219: DB::DecimalArithmeticsImpl>>, DB::DataTypeDecimal>>, DB::DataTypeDecimal>>, DB::(anonymous namespace)::MultiplyDecimalsImpl>::execute(DB::(anonymous namespace)::MultiplyDecimalsImpl, std::vector> const&, std::shared_ptr const&, unsigned long) @ 0x000000000da1dc86 7. /build/src/Functions/FunctionsDecimalArithmetics.h:368: DB::FunctionsDecimalArithmetics::resolveOverload(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000da198c4 8. /build/src/Functions/FunctionsDecimalArithmetics.h:298: DB::FunctionsDecimalArithmetics::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000da18b52 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:15:17.000806 [ 27539 ] {1fb717a3-a39a-49cd-abe7-4ba8a6f9e5ec} executeQuery: Code: 407. DB::Exception: Numeric overflow: result bigger that Decimal256: In scope SELECT divideDecimal(toDecimal256(1e72, 0), toDecimal256(0.00001, 5), 2). (DECIMAL_OVERFLOW) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52976) (comment: 02475_precise_decimal_arithmetics.sql) (query 8, line 15) (in query: SELECT divideDecimal(toDecimal256(1e72, 0), toDecimal256(1e-5, 5), 2);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/divideDecimal.cpp:53: DB::Decimal> DB::(anonymous namespace)::DivideDecimalsImpl::execute>, DB::Decimal>>(DB::Decimal>, DB::Decimal>, unsigned short, unsigned short, unsigned short) @ 0x000000000b528c90 5. /build/src/Functions/FunctionsDecimalArithmetics.h:172: void DB::Processor>>, DB::(anonymous namespace)::DivideDecimalsImpl>::vectorVector>, 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 short, unsigned short, unsigned short, unsigned long) const @ 0x000000000b5281e3 6. /build/src/Functions/FunctionsDecimalArithmetics.h:219: DB::DecimalArithmeticsImpl>>, DB::DataTypeDecimal>>, DB::DataTypeDecimal>>, DB::(anonymous namespace)::DivideDecimalsImpl>::execute(DB::(anonymous namespace)::DivideDecimalsImpl, std::vector> const&, std::shared_ptr const&, unsigned long) @ 0x000000000b51c146 7. /build/src/Functions/FunctionsDecimalArithmetics.h:368: DB::FunctionsDecimalArithmetics::resolveOverload(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b517d84 8. /build/src/Functions/FunctionsDecimalArithmetics.h:298: DB::FunctionsDecimalArithmetics::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b517012 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:15:17.018081 [ 27539 ] {} TCPHandler: Code: 407. DB::Exception: Numeric overflow: result bigger that Decimal256: In scope SELECT divideDecimal(toDecimal256(1e72, 0), toDecimal256(0.00001, 5), 2). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/divideDecimal.cpp:53: DB::Decimal> DB::(anonymous namespace)::DivideDecimalsImpl::execute>, DB::Decimal>>(DB::Decimal>, DB::Decimal>, unsigned short, unsigned short, unsigned short) @ 0x000000000b528c90 5. /build/src/Functions/FunctionsDecimalArithmetics.h:172: void DB::Processor>>, DB::(anonymous namespace)::DivideDecimalsImpl>::vectorVector>, 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 short, unsigned short, unsigned short, unsigned long) const @ 0x000000000b5281e3 6. /build/src/Functions/FunctionsDecimalArithmetics.h:219: DB::DecimalArithmeticsImpl>>, DB::DataTypeDecimal>>, DB::DataTypeDecimal>>, DB::(anonymous namespace)::DivideDecimalsImpl>::execute(DB::(anonymous namespace)::DivideDecimalsImpl, std::vector> const&, std::shared_ptr const&, unsigned long) @ 0x000000000b51c146 7. /build/src/Functions/FunctionsDecimalArithmetics.h:368: DB::FunctionsDecimalArithmetics::resolveOverload(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b517d84 8. /build/src/Functions/FunctionsDecimalArithmetics.h:298: DB::FunctionsDecimalArithmetics::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b517012 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:15:17.198309 [ 27539 ] {496a7935-6a77-4c2a-91d4-04d9fbbaf417} executeQuery: Code: 407. DB::Exception: Numeric overflow: result bigger that Decimal256: In scope SELECT multiplyDecimal(toDecimal256('1e38', 0), toDecimal256('1e38', 0)). (DECIMAL_OVERFLOW) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52976) (comment: 02475_precise_decimal_arithmetics.sql) (query 9, line 17) (in query: -- does not fit Decimal256 SELECT multiplyDecimal(toDecimal256('1e38', 0), toDecimal256('1e38', 0));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/multiplyDecimal.cpp:52: DB::Decimal> DB::(anonymous namespace)::MultiplyDecimalsImpl::execute>, DB::Decimal>>(DB::Decimal>, DB::Decimal>, unsigned short, unsigned short, unsigned short) @ 0x000000000da2a2c6 5. /build/src/Functions/FunctionsDecimalArithmetics.h:172: void DB::Processor>>, DB::(anonymous namespace)::MultiplyDecimalsImpl>::vectorVector>, 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 short, unsigned short, unsigned short, unsigned long) const @ 0x000000000da29803 6. /build/src/Functions/FunctionsDecimalArithmetics.h:219: DB::DecimalArithmeticsImpl>>, DB::DataTypeDecimal>>, DB::DataTypeDecimal>>, DB::(anonymous namespace)::MultiplyDecimalsImpl>::execute(DB::(anonymous namespace)::MultiplyDecimalsImpl, std::vector> const&, std::shared_ptr const&, unsigned long) @ 0x000000000da1dc86 7. /build/src/Functions/FunctionsDecimalArithmetics.h:368: DB::FunctionsDecimalArithmetics::resolveOverload(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000da198c4 8. /build/src/Functions/FunctionsDecimalArithmetics.h:298: DB::FunctionsDecimalArithmetics::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000da18b52 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:15:17.221655 [ 27539 ] {} TCPHandler: Code: 407. DB::Exception: Numeric overflow: result bigger that Decimal256: In scope SELECT multiplyDecimal(toDecimal256('1e38', 0), toDecimal256('1e38', 0)). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/multiplyDecimal.cpp:52: DB::Decimal> DB::(anonymous namespace)::MultiplyDecimalsImpl::execute>, DB::Decimal>>(DB::Decimal>, DB::Decimal>, unsigned short, unsigned short, unsigned short) @ 0x000000000da2a2c6 5. /build/src/Functions/FunctionsDecimalArithmetics.h:172: void DB::Processor>>, DB::(anonymous namespace)::MultiplyDecimalsImpl>::vectorVector>, 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 short, unsigned short, unsigned short, unsigned long) const @ 0x000000000da29803 6. /build/src/Functions/FunctionsDecimalArithmetics.h:219: DB::DecimalArithmeticsImpl>>, DB::DataTypeDecimal>>, DB::DataTypeDecimal>>, DB::(anonymous namespace)::MultiplyDecimalsImpl>::execute(DB::(anonymous namespace)::MultiplyDecimalsImpl, std::vector> const&, std::shared_ptr const&, unsigned long) @ 0x000000000da1dc86 7. /build/src/Functions/FunctionsDecimalArithmetics.h:368: DB::FunctionsDecimalArithmetics::resolveOverload(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000da198c4 8. /build/src/Functions/FunctionsDecimalArithmetics.h:298: DB::FunctionsDecimalArithmetics::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000da18b52 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:15:17.366603 [ 27539 ] {b588bf28-45d7-4a56-85c8-a63eab3d4056} executeQuery: Code: 407. DB::Exception: Numeric overflow: result bigger that Decimal256: In scope SELECT multiplyDecimal(toDecimal256(1e39, 0), toDecimal256(1e39, 0), 0). (DECIMAL_OVERFLOW) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52976) (comment: 02475_precise_decimal_arithmetics.sql) (query 10, line 19) (in query: SELECT multiplyDecimal(toDecimal256(1e39, 0), toDecimal256(1e39, 0), 0);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/multiplyDecimal.cpp:52: DB::Decimal> DB::(anonymous namespace)::MultiplyDecimalsImpl::execute>, DB::Decimal>>(DB::Decimal>, DB::Decimal>, unsigned short, unsigned short, unsigned short) @ 0x000000000da2a2c6 5. /build/src/Functions/FunctionsDecimalArithmetics.h:172: void DB::Processor>>, DB::(anonymous namespace)::MultiplyDecimalsImpl>::vectorVector>, 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 short, unsigned short, unsigned short, unsigned long) const @ 0x000000000da29803 6. /build/src/Functions/FunctionsDecimalArithmetics.h:219: DB::DecimalArithmeticsImpl>>, DB::DataTypeDecimal>>, DB::DataTypeDecimal>>, DB::(anonymous namespace)::MultiplyDecimalsImpl>::execute(DB::(anonymous namespace)::MultiplyDecimalsImpl, std::vector> const&, std::shared_ptr const&, unsigned long) @ 0x000000000da1dc86 7. /build/src/Functions/FunctionsDecimalArithmetics.h:368: DB::FunctionsDecimalArithmetics::resolveOverload(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000da198c4 8. /build/src/Functions/FunctionsDecimalArithmetics.h:298: DB::FunctionsDecimalArithmetics::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000da18b52 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:15:17.460497 [ 27539 ] {} TCPHandler: Code: 407. DB::Exception: Numeric overflow: result bigger that Decimal256: In scope SELECT multiplyDecimal(toDecimal256(1e39, 0), toDecimal256(1e39, 0), 0). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/multiplyDecimal.cpp:52: DB::Decimal> DB::(anonymous namespace)::MultiplyDecimalsImpl::execute>, DB::Decimal>>(DB::Decimal>, DB::Decimal>, unsigned short, unsigned short, unsigned short) @ 0x000000000da2a2c6 5. /build/src/Functions/FunctionsDecimalArithmetics.h:172: void DB::Processor>>, DB::(anonymous namespace)::MultiplyDecimalsImpl>::vectorVector>, 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 short, unsigned short, unsigned short, unsigned long) const @ 0x000000000da29803 6. /build/src/Functions/FunctionsDecimalArithmetics.h:219: DB::DecimalArithmeticsImpl>>, DB::DataTypeDecimal>>, DB::DataTypeDecimal>>, DB::(anonymous namespace)::MultiplyDecimalsImpl>::execute(DB::(anonymous namespace)::MultiplyDecimalsImpl, std::vector> const&, std::shared_ptr const&, unsigned long) @ 0x000000000da1dc86 7. /build/src/Functions/FunctionsDecimalArithmetics.h:368: DB::FunctionsDecimalArithmetics::resolveOverload(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000da198c4 8. /build/src/Functions/FunctionsDecimalArithmetics.h:298: DB::FunctionsDecimalArithmetics::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000da18b52 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:15:17.670440 [ 27539 ] {fdc3814c-52b8-4892-b9a0-1a7594f2e9dd} executeQuery: Code: 407. DB::Exception: Numeric overflow: result bigger that Decimal256: In scope SELECT divideDecimal(toDecimal256(1e39, 0), toDecimal256(1e-38, 39)). (DECIMAL_OVERFLOW) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52976) (comment: 02475_precise_decimal_arithmetics.sql) (query 11, line 20) (in query: SELECT divideDecimal(toDecimal256(1e39, 0), toDecimal256(1e-38, 39));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/divideDecimal.cpp:53: DB::Decimal> DB::(anonymous namespace)::DivideDecimalsImpl::execute>, DB::Decimal>>(DB::Decimal>, DB::Decimal>, unsigned short, unsigned short, unsigned short) @ 0x000000000b528c90 5. /build/src/Functions/FunctionsDecimalArithmetics.h:172: void DB::Processor>>, DB::(anonymous namespace)::DivideDecimalsImpl>::vectorVector>, 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 short, unsigned short, unsigned short, unsigned long) const @ 0x000000000b5281e3 6. /build/src/Functions/FunctionsDecimalArithmetics.h:219: DB::DecimalArithmeticsImpl>>, DB::DataTypeDecimal>>, DB::DataTypeDecimal>>, DB::(anonymous namespace)::DivideDecimalsImpl>::execute(DB::(anonymous namespace)::DivideDecimalsImpl, std::vector> const&, std::shared_ptr const&, unsigned long) @ 0x000000000b51c146 7. /build/src/Functions/FunctionsDecimalArithmetics.h:368: DB::FunctionsDecimalArithmetics::resolveOverload(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b517d84 8. /build/src/Functions/FunctionsDecimalArithmetics.h:298: DB::FunctionsDecimalArithmetics::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b517012 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:15:17.708201 [ 27539 ] {} TCPHandler: Code: 407. DB::Exception: Numeric overflow: result bigger that Decimal256: In scope SELECT divideDecimal(toDecimal256(1e39, 0), toDecimal256(1e-38, 39)). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/divideDecimal.cpp:53: DB::Decimal> DB::(anonymous namespace)::DivideDecimalsImpl::execute>, DB::Decimal>>(DB::Decimal>, DB::Decimal>, unsigned short, unsigned short, unsigned short) @ 0x000000000b528c90 5. /build/src/Functions/FunctionsDecimalArithmetics.h:172: void DB::Processor>>, DB::(anonymous namespace)::DivideDecimalsImpl>::vectorVector>, 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 short, unsigned short, unsigned short, unsigned long) const @ 0x000000000b5281e3 6. /build/src/Functions/FunctionsDecimalArithmetics.h:219: DB::DecimalArithmeticsImpl>>, DB::DataTypeDecimal>>, DB::DataTypeDecimal>>, DB::(anonymous namespace)::DivideDecimalsImpl>::execute(DB::(anonymous namespace)::DivideDecimalsImpl, std::vector> const&, std::shared_ptr const&, unsigned long) @ 0x000000000b51c146 7. /build/src/Functions/FunctionsDecimalArithmetics.h:368: DB::FunctionsDecimalArithmetics::resolveOverload(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b517d84 8. /build/src/Functions/FunctionsDecimalArithmetics.h:298: DB::FunctionsDecimalArithmetics::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b517012 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:15:18.243317 [ 3543 ] {8a0a1d08-65e5-45d5-ab09-56d4750ad7ec} executeQuery: Code: 36. DB::Exception: Dictionary (`test_9.dict1`) not found: In scope SELECT dictGetUInt8(concat('test_9', '.dict1'), 'second_column', (toUInt64(11), '121')). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52898) (comment: 01018_ddl_dictionaries_select.sql) (query 28, line 89) (in query: SELECT dictGetUInt8(concat('test_9', '.dict1'), 'second_column', (toUInt64(11), '121'))), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Interpreters/ExternalDictionariesLoader.cpp:168: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x00000000147cba28 5. /build/src/Interpreters/ExternalDictionariesLoader.cpp:113: DB::ExternalDictionariesLoader::getDictionaryStructure(String const&, std::shared_ptr) const @ 0x00000000147cbec4 6. /build/src/Functions/FunctionsExternalDictionaries.h:138: DB::FunctionDictHelper::getDictionaryStructure(String const&) const @ 0x000000000a1177ad 7. /build/src/Functions/FunctionsExternalDictionaries.h:375: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a1139b8 8. /build/src/Functions/FunctionsExternalDictionaries.h:823: DB::FunctionDictGetImpl, DB::NameDictGetUInt8, (DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a123bef 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:15:18.250807 [ 3543 ] {} TCPHandler: Code: 36. DB::Exception: Dictionary (`test_9.dict1`) not found: In scope SELECT dictGetUInt8(concat('test_9', '.dict1'), 'second_column', (toUInt64(11), '121')). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Interpreters/ExternalDictionariesLoader.cpp:168: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x00000000147cba28 5. /build/src/Interpreters/ExternalDictionariesLoader.cpp:113: DB::ExternalDictionariesLoader::getDictionaryStructure(String const&, std::shared_ptr) const @ 0x00000000147cbec4 6. /build/src/Functions/FunctionsExternalDictionaries.h:138: DB::FunctionDictHelper::getDictionaryStructure(String const&) const @ 0x000000000a1177ad 7. /build/src/Functions/FunctionsExternalDictionaries.h:375: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a1139b8 8. /build/src/Functions/FunctionsExternalDictionaries.h:823: DB::FunctionDictGetImpl, DB::NameDictGetUInt8, (DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a123bef 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:15:19.777844 [ 27693 ] {7c38bf47-cfb6-4679-9c65-dea8e09e0c22} test_3.table_one (a0a86c7f-a683-462f-9a92-29220c16e2eb): 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:15:19.927168 [ 5085 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:15:20.514066 [ 30862 ] {9c009363-fca6-4c17-86f6-3e1a049a9019} executeQuery: Code: 57. DB::Exception: Table test_7.t1 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58226) (comment: 03042_not_found_column_c1.sql) (query 3, line 5) (in query: CREATE TABLE t1 (c0 Int32, c1 Int32, c2 Int32) ENGINE = Memory() ;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:15:20.547481 [ 30862 ] {} TCPHandler: Code: 57. DB::Exception: Table test_7.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:15:21.672342 [ 30862 ] {4e1b3867-b73f-4017-846c-3f91ae9503c6} PushingToViews: Failed to push block to view test_7.mview (827856b2-0979-4c5c-89fc-b66a024f0d41), Unknown expression identifier `n` in scope SELECT n, n * n AS n2 FROM test_7.test_table 2025.07.13 02:15:21.678806 [ 30862 ] {4e1b3867-b73f-4017-846c-3f91ae9503c6} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `n` in scope SELECT n, n * n AS n2 FROM test_7.test_table. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58234) (comment: 02384_analyzer_dict_get_join_get.sql) (query 4, line 10) (in query: INSERT INTO test_table VALUES ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000013f69e39 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f3a889 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001489281b 14. /build/src/Processors/Transforms/buildPushingToViewsChain.cpp:352: DB::generateViewChain(std::shared_ptr, unsigned long, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x0000000016bd4539 15. /build/src/Processors/Transforms/buildPushingToViewsChain.cpp:530: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000016bd8431 16. /build/src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000001484c2eb 17. /build/src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000001484dcd2 18. /build/src/Interpreters/InterpreterInsertQuery.cpp:755: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000148509b4 19. /build/src/Interpreters/InterpreterInsertQuery.cpp:875: DB::InterpreterInsertQuery::execute() @ 0x0000000014852193 20. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:15:21.686995 [ 30862 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `n` in scope SELECT n, n * n AS n2 FROM test_7.test_table. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000013f69e39 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f3a889 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001489281b 14. /build/src/Processors/Transforms/buildPushingToViewsChain.cpp:352: DB::generateViewChain(std::shared_ptr, unsigned long, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x0000000016bd4539 15. /build/src/Processors/Transforms/buildPushingToViewsChain.cpp:530: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000016bd8431 16. /build/src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000001484c2eb 17. /build/src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000001484dcd2 18. /build/src/Interpreters/InterpreterInsertQuery.cpp:755: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000148509b4 19. /build/src/Interpreters/InterpreterInsertQuery.cpp:875: DB::InterpreterInsertQuery::execute() @ 0x0000000014852193 20. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:15:22.463815 [ 27693 ] {bfbe3496-b388-45bc-8dfd-8b9350a1b216} executeQuery: Code: 57. DB::Exception: Table test_3.table_one already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58200) (comment: 02422_insert_different_granularity.sql) (query 10, line 25) (in query: CREATE TABLE table_one (`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 = 1., replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 244736704, compact_parts_max_bytes_to_buffer = 57331060, compact_parts_max_granules_to_buffer = 160, compact_parts_merge_max_bytes_to_prefetch_part = 9540962, merge_max_block_size = 5766, 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 = 81, min_merge_bytes_to_use_direct_io = 10737418240, use_const_adaptive_granularity = false, 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 = false, marks_compress_block_size = 83382, primary_key_compress_block_size = 29086, use_primary_key_cache = false, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:15:22.489576 [ 27693 ] {} TCPHandler: Code: 57. DB::Exception: Table test_3.table_one already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:15:23.302596 [ 31788 ] {61c8dac1-f1ab-4199-8a89-c8cc36905740} executeQuery: Code: 43. DB::Exception: Illegal type Array(Variant(Tuple(UInt8, UInt8))) expression, must be numeric type. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58282) (comment: 03203_variant_convert_field_to_type_bug.sql) (query 3, line 4) (in query: SELECT * FROM numbers([tuple(1, 2), NULL], 2);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/TableFunctions/TableFunctionNumbers.cpp:105: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x000000001170e12b 5. /build/src/TableFunctions/TableFunctionNumbers.cpp:79: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000001170d2af 6. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000130d4903 7. /build/src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000143537f2 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3da49 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:15:23.323706 [ 31788 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Variant(Tuple(UInt8, UInt8))) expression, must be numeric type. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/TableFunctions/TableFunctionNumbers.cpp:105: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x000000001170e12b 5. /build/src/TableFunctions/TableFunctionNumbers.cpp:79: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000001170d2af 6. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000130d4903 7. /build/src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000143537f2 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3da49 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:15:23.373958 [ 3543 ] {d47de6cf-9653-4677-84f8-74709fa439da} executeQuery: Code: 36. DB::Exception: Dictionary (`default.dict3`) not found. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52898) (comment: 01018_ddl_dictionaries_select.sql) (query 40, line 131) (in query: SELECT dictGetString(default.dict3, 'some_column', toUInt64(12));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Interpreters/ExternalDictionariesLoader.cpp:168: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x00000000147cba28 5. /build/src/Interpreters/ExternalDictionariesLoader.cpp:113: DB::ExternalDictionariesLoader::getDictionaryStructure(String const&, std::shared_ptr) const @ 0x00000000147cbec4 6. /build/src/Interpreters/ExternalDictionariesLoader.cpp:131: DB::ExternalDictionariesLoader::assertDictionaryStructureExists(String const&, std::shared_ptr) const @ 0x00000000147cc2d4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2821: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4e4d5 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:15:23.383037 [ 3543 ] {} TCPHandler: Code: 36. DB::Exception: Dictionary (`default.dict3`) not found. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Interpreters/ExternalDictionariesLoader.cpp:168: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x00000000147cba28 5. /build/src/Interpreters/ExternalDictionariesLoader.cpp:113: DB::ExternalDictionariesLoader::getDictionaryStructure(String const&, std::shared_ptr) const @ 0x00000000147cbec4 6. /build/src/Interpreters/ExternalDictionariesLoader.cpp:131: DB::ExternalDictionariesLoader::assertDictionaryStructureExists(String const&, std::shared_ptr) const @ 0x00000000147cc2d4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2821: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4e4d5 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:15:24.004352 [ 3543 ] {44ca40d4-4af9-4cda-9330-46441d14c067} executeQuery: Code: 36. DB::Exception: Dictionary (`default.dict3`) not found. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52898) (comment: 01018_ddl_dictionaries_select.sql) (query 43, line 134) (in query: SELECT dictGet(default.dict3, 'some_column', toUInt64(12));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Interpreters/ExternalDictionariesLoader.cpp:168: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x00000000147cba28 5. /build/src/Interpreters/ExternalDictionariesLoader.cpp:113: DB::ExternalDictionariesLoader::getDictionaryStructure(String const&, std::shared_ptr) const @ 0x00000000147cbec4 6. /build/src/Interpreters/ExternalDictionariesLoader.cpp:131: DB::ExternalDictionariesLoader::assertDictionaryStructureExists(String const&, std::shared_ptr) const @ 0x00000000147cc2d4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2821: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4e4d5 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:15:24.022814 [ 3543 ] {} TCPHandler: Code: 36. DB::Exception: Dictionary (`default.dict3`) not found. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Interpreters/ExternalDictionariesLoader.cpp:168: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x00000000147cba28 5. /build/src/Interpreters/ExternalDictionariesLoader.cpp:113: DB::ExternalDictionariesLoader::getDictionaryStructure(String const&, std::shared_ptr) const @ 0x00000000147cbec4 6. /build/src/Interpreters/ExternalDictionariesLoader.cpp:131: DB::ExternalDictionariesLoader::assertDictionaryStructureExists(String const&, std::shared_ptr) const @ 0x00000000147cc2d4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2821: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4e4d5 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:15:24.083724 [ 27693 ] {1f0a0c8b-5e41-4f57-8fd4-01b19d69ca65} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `value` in scope SELECT * FROM merge(currentDatabase(), '') WHERE value = 1048575. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58268) (comment: 02522_different_types_in_storage_merge.sql) (query 6, line 8) (in query: SELECT * FROM merge(currentDatabase(), '') WHERE value = 1048575;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000013f69e39 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f3a889 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3236a 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 16. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:15:24.116327 [ 27693 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `value` in scope SELECT * FROM merge(currentDatabase(), '') WHERE value = 1048575. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000013f69e39 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f3a889 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3236a 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 16. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:15:24.911910 [ 27693 ] {726d9c47-0270-45a0-b835-ee7de502cee4} 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]:55324) (comment: 03171_hashed_dictionary_short_circuit_bug_fix.sql) (in query: DROP DATABASE IF EXISTS test_la8463h2 SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:15:24.914606 [ 27693 ] {726d9c47-0270-45a0-b835-ee7de502cee4} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:15:24.989819 [ 12975 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:15:24.990273 [ 27539 ] {0a288894-e25b-47e0-98a4-db2981b6bde0} executeQuery: Code: 50. DB::Exception: Unknown data type family: ab. (UNKNOWN_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58314) (comment: 03144_fuzz_quoted_type_name.sql) (query 1, line 5) (in query: create table t (x Array(`ab`)) engine Memory;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/DataTypes/DataTypeFactory.cpp:252: std::function (std::shared_ptr const&)> const* DB::DataTypeFactory::findCreatorByName(String const&) const @ 0x0000000013b0e953 5. /build/src/DataTypes/DataTypeFactory.cpp:125: std::shared_ptr DB::DataTypeFactory::getImpl(String const&, std::shared_ptr const&) const @ 0x0000000013b0e24d 6. /build/src/DataTypes/DataTypeFactory.cpp:91: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000013b0dcfe 7. /build/src/DataTypes/DataTypeArray.cpp:104: DB::create(std::shared_ptr const&) @ 0x0000000013afe497 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013b0e25b 9. /build/src/DataTypes/DataTypeFactory.cpp:91: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000013b0dcfe 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:569: DB::InterpreterCreateQuery::getColumnType(DB::ASTColumnDeclaration const&, DB::LoadingStrictnessLevel, bool) @ 0x000000001480a797 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:625: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000001480ac8f 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001480c764 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000001481759b 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:15:25.003937 [ 27539 ] {} TCPHandler: Code: 50. DB::Exception: Unknown data type family: ab. (UNKNOWN_TYPE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/DataTypes/DataTypeFactory.cpp:252: std::function (std::shared_ptr const&)> const* DB::DataTypeFactory::findCreatorByName(String const&) const @ 0x0000000013b0e953 5. /build/src/DataTypes/DataTypeFactory.cpp:125: std::shared_ptr DB::DataTypeFactory::getImpl(String const&, std::shared_ptr const&) const @ 0x0000000013b0e24d 6. /build/src/DataTypes/DataTypeFactory.cpp:91: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000013b0dcfe 7. /build/src/DataTypes/DataTypeArray.cpp:104: DB::create(std::shared_ptr const&) @ 0x0000000013afe497 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013b0e25b 9. /build/src/DataTypes/DataTypeFactory.cpp:91: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000013b0dcfe 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:569: DB::InterpreterCreateQuery::getColumnType(DB::ASTColumnDeclaration const&, DB::LoadingStrictnessLevel, bool) @ 0x000000001480a797 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:625: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000001480ac8f 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001480c764 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000001481759b 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:15:25.038324 [ 27539 ] {de7227c6-1d4e-409a-973b-9297f320d38c} executeQuery: Code: 50. DB::Exception: Unknown data type family: ab. (UNKNOWN_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58314) (comment: 03144_fuzz_quoted_type_name.sql) (query 2, line 6) (in query: create table t (x `ab`) engine Memory;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/DataTypes/DataTypeFactory.cpp:252: std::function (std::shared_ptr const&)> const* DB::DataTypeFactory::findCreatorByName(String const&) const @ 0x0000000013b0e953 5. /build/src/DataTypes/DataTypeFactory.cpp:125: std::shared_ptr DB::DataTypeFactory::getImpl(String const&, std::shared_ptr const&) const @ 0x0000000013b0e24d 6. /build/src/DataTypes/DataTypeFactory.cpp:91: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000013b0dcfe 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:569: DB::InterpreterCreateQuery::getColumnType(DB::ASTColumnDeclaration const&, DB::LoadingStrictnessLevel, bool) @ 0x000000001480a797 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:625: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000001480ac8f 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001480c764 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000001481759b 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 14. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 15. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 20. ? @ 0x00007f7210eb6ac3 21. ? @ 0x00007f7210f48850 2025.07.13 02:15:25.047223 [ 27539 ] {} TCPHandler: Code: 50. DB::Exception: Unknown data type family: ab. (UNKNOWN_TYPE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/DataTypes/DataTypeFactory.cpp:252: std::function (std::shared_ptr const&)> const* DB::DataTypeFactory::findCreatorByName(String const&) const @ 0x0000000013b0e953 5. /build/src/DataTypes/DataTypeFactory.cpp:125: std::shared_ptr DB::DataTypeFactory::getImpl(String const&, std::shared_ptr const&) const @ 0x0000000013b0e24d 6. /build/src/DataTypes/DataTypeFactory.cpp:91: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000013b0dcfe 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:569: DB::InterpreterCreateQuery::getColumnType(DB::ASTColumnDeclaration const&, DB::LoadingStrictnessLevel, bool) @ 0x000000001480a797 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:625: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000001480ac8f 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001480c764 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000001481759b 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 14. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 15. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 20. ? @ 0x00007f7210eb6ac3 21. ? @ 0x00007f7210f48850 2025.07.13 02:15:25.195420 [ 27539 ] {dd2751c2-fa5a-492e-80d6-d03049a5ef6d} executeQuery: Code: 57. DB::Exception: Table test_13.t already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58314) (comment: 03144_fuzz_quoted_type_name.sql) (query 3, line 7) (in query: create table t (x `Int64`) engine Memory;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:15:25.210270 [ 27539 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:15:25.568070 [ 37313 ] {1e04aa82-36a2-46e5-a9db-dd6065301475} 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]:58324) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:15:25.580364 [ 37313 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:15:27.378131 [ 31799 ] {} TCPHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000013779f8b 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000137794b8 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778c58 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168167bf 10. /build/src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000001680ff45 11. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:15:27.381315 [ 31799 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x0000000016810069 5. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 6. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 2025.07.13 02:15:27.409194 [ 37316 ] {b4581a09-c5c7-4fa0-9925-6bb84a159a4f} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000013779f8b 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000137794b8 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778c58 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168167bf 10. /build/src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000001680ff45 11. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58370) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fb80677 3. /build/src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x00000000166f5247 4. /build/src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000166fc432 5. /build/src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001673a5f3 6. /build/src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013af6952 7. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013af679a 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013af64e1 2025.07.13 02:15:27.504241 [ 37316 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000013779f8b 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000137794b8 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778c58 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168167bf 10. /build/src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000001680ff45 11. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fb80677 3. /build/src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x00000000166f5247 4. /build/src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000166fc432 5. /build/src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001673a5f3 6. /build/src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013af6952 7. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013af679a 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013af64e1 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:15:30.267481 [ 11489 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:15:32.278463 [ 30862 ] {9dc472ba-49ed-4f15-bf85-cea89966f53d} executeQuery: Code: 471. DB::Exception: Could not specify `disk` and `storage_policy` at the same time for storage Log Family. (INVALID_SETTING_VALUE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58422) (comment: 02554_log_faminy_support_storage_policy.sql) (query 16, line 27) (in query: CREATE TABLE test_2554_error (n UInt32) ENGINE = Log SETTINGS disk = 'default', storage_policy = 'default';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Storages/StorageLogSettings.cpp:27: DB::getDiskName(DB::ASTStorage&, std::shared_ptr) @ 0x0000000015f8bf45 5. /build/src/Storages/StorageLog.cpp:1188: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:se190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000015f86846 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ca1a22 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001481ee32 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:15:32.335489 [ 30862 ] {} TCPHandler: Code: 471. DB::Exception: Could not specify `disk` and `storage_policy` at the same time for storage Log Family. (INVALID_SETTING_VALUE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Storages/StorageLogSettings.cpp:27: DB::getDiskName(DB::ASTStorage&, std::shared_ptr) @ 0x0000000015f8bf45 5. /build/src/Storages/StorageLog.cpp:1188: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:se190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000015f86846 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ca1a22 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001481ee32 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:15:34.651639 [ 4930 ] {d431cdbb-67a3-471d-a11b-d6409205fe7e} executeQuery: Code: 159. DB::Exception: Timeout exceeded (180 s) while flushing system log 'DB::SystemLogQueue'. (TIMEOUT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52320) (comment: 01526_max_untracked_memory.sh) (query 1, line 1) (in query: SYSTEM FLUSH LOGS trace_log), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Common/SystemLogBase.cpp:168: DB::SystemLogQueue::waitFlush(long, bool) @ 0x000000000fbee407 5. /build/src/Interpreters/SystemLog.cpp:437: DB::SystemLogs::flush(bool, std::vector> const&) @ 0x0000000014a1ea9f 6. /build/src/Interpreters/InterpreterSystemQuery.cpp:796: DB::InterpreterSystemQuery::execute() @ 0x0000000014bd5a4e 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:15:34.660651 [ 4930 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded (180 s) while flushing system log 'DB::SystemLogQueue'. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Common/SystemLogBase.cpp:168: DB::SystemLogQueue::waitFlush(long, bool) @ 0x000000000fbee407 5. /build/src/Interpreters/SystemLog.cpp:437: DB::SystemLogs::flush(bool, std::vector> const&) @ 0x0000000014a1ea9f 6. /build/src/Interpreters/InterpreterSystemQuery.cpp:796: DB::InterpreterSystemQuery::execute() @ 0x0000000014bd5a4e 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:15:35.084916 [ 31799 ] {7f8660a9-b52f-4a84-a096-b8cd0f1db19e} InterpreterCreateQuery: ATTACH TABLE query with full table definition is not recommended: use either ATTACH TABLE data_read; to attach existing table or CREATE TABLE data_read
; to create new table or ATTACH TABLE data_read FROM '/path/to/data/'
; to create new table and attach data. 2025.07.13 02:15:35.241080 [ 4547 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:15:37.601031 [ 3785 ] {} ordinary_test_7.data_read (ReplicatedMergeTreeAttachThread): No metadata in ZooKeeper for /tables/ordinary_test_7/data/replicas/read: table will stay in readonly mode 2025.07.13 02:15:38.191623 [ 31799 ] {5746eacb-f0a4-4896-8760-b62c1e7f3a37} 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]:47416) (comment: 02980_s3_plain_DROP_TABLE_ReplicatedMergeTree.sh) (query 4, line 12) (in query: insert into data_read values ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:5954: DB::StorageReplicatedMergeTree::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000015e408eb 5. /build/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&) @ 0x0000000016bd98a4 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000001484c2eb 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000001484dcd2 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:755: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000148509b4 9. /build/src/Interpreters/InterpreterInsertQuery.cpp:875: DB::InterpreterInsertQuery::execute() @ 0x0000000014852193 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:15:38.216211 [ 31799 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:5954: DB::StorageReplicatedMergeTree::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000015e408eb 5. /build/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&) @ 0x0000000016bd98a4 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000001484c2eb 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000001484dcd2 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:755: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000148509b4 9. /build/src/Interpreters/InterpreterInsertQuery.cpp:875: DB::InterpreterInsertQuery::execute() @ 0x0000000014852193 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:15:38.413223 [ 31799 ] {44d52b40-3fa6-4960-88d3-af58b6c62851} executeQuery: Code: 242. DB::Exception: Table is in readonly mode (replica path: /tables/ordinary_test_7/data/replicas/read). (TABLE_IS_READ_ONLY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47416) (comment: 02980_s3_plain_DROP_TABLE_ReplicatedMergeTree.sh) (query 5, line 13) (in query: optimize table data_read final;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:5937: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000015da5c84 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:6118: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x0000000015e41dac 6. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014bf58ce 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:15:38.437870 [ 31799 ] {} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode (replica path: /tables/ordinary_test_7/data/replicas/read). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:5937: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000015da5c84 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:6118: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x0000000015e41dac 6. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014bf58ce 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:15:38.787476 [ 31799 ] {e1295b68-3502-448d-adbe-c69582ed7b39} executeQuery: Code: 242. DB::Exception: Table is in readonly mode (replica path: /tables/ordinary_test_7/data/replicas/read). (TABLE_IS_READ_ONLY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47416) (comment: 02980_s3_plain_DROP_TABLE_ReplicatedMergeTree.sh) (query 6, line 14) (in query: system sync replica data_read;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:5937: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000015da5c84 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:329: DB::StorageReplicatedMergeTree::waitForProcessingQueue(unsigned long, DB::SyncReplicaMode, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000015e8fe79 6. /build/src/Interpreters/InterpreterSystemQuery.cpp:1265: DB::InterpreterSystemQuery::trySyncReplica(std::shared_ptr, DB::SyncReplicaMode, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr) @ 0x0000000014be7dd3 7. /build/src/Interpreters/InterpreterSystemQuery.cpp:1284: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x0000000014be07f1 8. /build/src/Interpreters/InterpreterSystemQuery.cpp:763: DB::InterpreterSystemQuery::execute() @ 0x0000000014bd4710 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:15:38.792807 [ 31799 ] {} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode (replica path: /tables/ordinary_test_7/data/replicas/read). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:5937: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000015da5c84 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:329: DB::StorageReplicatedMergeTree::waitForProcessingQueue(unsigned long, DB::SyncReplicaMode, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000015e8fe79 6. /build/src/Interpreters/InterpreterSystemQuery.cpp:1265: DB::InterpreterSystemQuery::trySyncReplica(std::shared_ptr, DB::SyncReplicaMode, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr) @ 0x0000000014be7dd3 7. /build/src/Interpreters/InterpreterSystemQuery.cpp:1284: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x0000000014be07f1 8. /build/src/Interpreters/InterpreterSystemQuery.cpp:763: DB::InterpreterSystemQuery::execute() @ 0x0000000014bd4710 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:15:39.752944 [ 27693 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000013779f8b 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000137794b8 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778bc3 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678d325 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:15:40.475152 [ 12974 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:15:45.481518 [ 5822 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:15:49.110812 [ 31831 ] {b36d8879-5ebd-430e-882a-366653a80316} 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]:39050) (comment: 01084_regexp_empty.sql) (query 6, line 9) (in query: DROP DATABASE test_5_1), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:15:49.184450 [ 31831 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:15:50.532452 [ 12975 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:15:54.286708 [ 27693 ] {1d09506a-f06f-4785-ac28-6af5984933f8} executeQuery: Code: 42. DB::Exception: Number of arguments for function punycodeEncode doesn't match: passed 0, should be 1: In scope SELECT punycodeEncode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34114) (comment: 02932_punycode.sql) (query 2, line 8) (in query: SELECT punycodeEncode();), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000011fa678b 4. /build/src/Functions/IFunction.cpp:539: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000012c80d4d 5. /build/src/Functions/IFunction.cpp:593: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c81533 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:15:54.294063 [ 27693 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function punycodeEncode doesn't match: passed 0, should be 1: In scope SELECT punycodeEncode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000011fa678b 4. /build/src/Functions/IFunction.cpp:539: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000012c80d4d 5. /build/src/Functions/IFunction.cpp:593: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c81533 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:15:54.382856 [ 27693 ] {2325026e-50da-44c3-be5e-4bb2a38a654c} executeQuery: Code: 42. DB::Exception: Number of arguments for function punycodeDecode doesn't match: passed 0, should be 1: In scope SELECT punycodeDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34114) (comment: 02932_punycode.sql) (query 3, line 9) (in query: SELECT punycodeDecode();), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000011fa678b 4. /build/src/Functions/IFunction.cpp:539: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000012c80d4d 5. /build/src/Functions/IFunction.cpp:593: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c81533 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:15:54.398802 [ 27693 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function punycodeDecode doesn't match: passed 0, should be 1: In scope SELECT punycodeDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000011fa678b 4. /build/src/Functions/IFunction.cpp:539: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000012c80d4d 5. /build/src/Functions/IFunction.cpp:593: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c81533 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:15:54.463781 [ 27693 ] {541a4549-7f0c-4137-9534-51d1db2094fb} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryPunycodeDecode doesn't match: passed 0, should be 1: In scope SELECT tryPunycodeDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34114) (comment: 02932_punycode.sql) (query 4, line 10) (in query: SELECT tryPunycodeDecode();), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000011fa678b 4. /build/src/Functions/IFunction.cpp:539: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000012c80d4d 5. /build/src/Functions/IFunction.cpp:593: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c81533 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:15:54.492588 [ 27693 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryPunycodeDecode doesn't match: passed 0, should be 1: In scope SELECT tryPunycodeDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000011fa678b 4. /build/src/Functions/IFunction.cpp:539: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000012c80d4d 5. /build/src/Functions/IFunction.cpp:593: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c81533 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:15:54.617346 [ 27693 ] {4e2e24be-88d6-4322-972c-0617a08767ab} executeQuery: Code: 43. DB::Exception: Illegal type UInt8 of argument of function punycodeEncode: In scope SELECT punycodeEncode(1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34114) (comment: 02932_punycode.sql) (query 5, line 12) (in query: SELECT punycodeEncode(1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/FunctionStringToString.h:54: DB::FunctionStringToString::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000e4afe19 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:15:54.655120 [ 27693 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type UInt8 of argument of function punycodeEncode: In scope SELECT punycodeEncode(1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/FunctionStringToString.h:54: DB::FunctionStringToString::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000e4afe19 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:15:54.869077 [ 27693 ] {6377448f-dbcb-4869-b5e0-190601e42812} executeQuery: Code: 43. DB::Exception: Illegal type UInt8 of argument of function punycodeDecode: In scope SELECT punycodeDecode(1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34114) (comment: 02932_punycode.sql) (query 6, line 13) (in query: SELECT punycodeDecode(1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/FunctionStringToString.h:54: DB::FunctionStringToString, DB::NamePunycodeDecode, false>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000e4b1179 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:15:54.875953 [ 27693 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type UInt8 of argument of function punycodeDecode: In scope SELECT punycodeDecode(1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/FunctionStringToString.h:54: DB::FunctionStringToString, DB::NamePunycodeDecode, false>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000e4b1179 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:15:55.123623 [ 27693 ] {a608326b-8090-4b30-9771-464094b0e9fd} executeQuery: Code: 43. DB::Exception: Illegal type UInt8 of argument of function tryPunycodeDecode: In scope SELECT tryPunycodeDecode(1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34114) (comment: 02932_punycode.sql) (query 7, line 14) (in query: SELECT tryPunycodeDecode(1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/FunctionStringToString.h:54: DB::FunctionStringToString, DB::NameTryPunycodeDecode, false>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000e4b2619 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:15:55.146527 [ 27693 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type UInt8 of argument of function tryPunycodeDecode: In scope SELECT tryPunycodeDecode(1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/FunctionStringToString.h:54: DB::FunctionStringToString, DB::NameTryPunycodeDecode, false>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000e4b2619 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:15:55.261468 [ 27693 ] {f821cb50-d2f3-4b7f-a6a1-7cfe978fdebd} executeQuery: Code: 42. DB::Exception: Number of arguments for function punycodeEncode doesn't match: passed 2, should be 1: In scope SELECT punycodeEncode('two', 'strings'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34114) (comment: 02932_punycode.sql) (query 8, line 16) (in query: SELECT punycodeEncode('two', 'strings');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000011fa678b 4. /build/src/Functions/IFunction.cpp:539: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000012c80d4d 5. /build/src/Functions/IFunction.cpp:593: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c81533 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:15:55.261848 [ 31831 ] {66bbe529-5fef-45ee-ac03-4663b3cb30fe} executeQuery: Code: 47. DB::Exception: Compound identifier 'lambda.nested' cannot be resolved as function. In scope WITH x -> (x + 1) AS lambda SELECT lambda.nested(1). (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34124) (comment: 02385_analyzer_aliases_compound_expression.sql) (query 5, line 9) (in query: WITH (x -> x + 1) AS lambda SELECT lambda.nested(1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, char const*&&, String&&) @ 0x0000000013f68a8b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1278: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000013f480ee 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000013f4856d 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2751: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4d5f8 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:15:55.269779 [ 27693 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function punycodeEncode doesn't match: passed 2, should be 1: In scope SELECT punycodeEncode('two', 'strings'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000011fa678b 4. /build/src/Functions/IFunction.cpp:539: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000012c80d4d 5. /build/src/Functions/IFunction.cpp:593: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c81533 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:15:55.270778 [ 31831 ] {} TCPHandler: Code: 47. DB::Exception: Compound identifier 'lambda.nested' cannot be resolved as function. In scope WITH x -> (x + 1) AS lambda SELECT lambda.nested(1). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, char const*&&, String&&) @ 0x0000000013f68a8b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1278: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000013f480ee 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000013f4856d 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2751: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4d5f8 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:15:55.389677 [ 27693 ] {5dd71b6b-d31a-47ff-89dd-0a2cad02d405} executeQuery: Code: 42. DB::Exception: Number of arguments for function punycodeDecode doesn't match: passed 2, should be 1: In scope SELECT punycodeDecode('two', 'strings'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34114) (comment: 02932_punycode.sql) (query 9, line 17) (in query: SELECT punycodeDecode('two', 'strings');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000011fa678b 4. /build/src/Functions/IFunction.cpp:539: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000012c80d4d 5. /build/src/Functions/IFunction.cpp:593: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c81533 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:15:55.411398 [ 27693 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function punycodeDecode doesn't match: passed 2, should be 1: In scope SELECT punycodeDecode('two', 'strings'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000011fa678b 4. /build/src/Functions/IFunction.cpp:539: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000012c80d4d 5. /build/src/Functions/IFunction.cpp:593: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c81533 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:15:55.479115 [ 27693 ] {a4d16618-cae7-4aff-9e40-fcc513706e74} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryPunycodeDecode doesn't match: passed 2, should be 1: In scope SELECT tryPunycodeDecode('two', 'strings'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34114) (comment: 02932_punycode.sql) (query 10, line 18) (in query: SELECT tryPunycodeDecode('two', 'strings');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000011fa678b 4. /build/src/Functions/IFunction.cpp:539: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000012c80d4d 5. /build/src/Functions/IFunction.cpp:593: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c81533 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:15:55.489342 [ 27693 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryPunycodeDecode doesn't match: passed 2, should be 1: In scope SELECT tryPunycodeDecode('two', 'strings'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000011fa678b 4. /build/src/Functions/IFunction.cpp:539: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000012c80d4d 5. /build/src/Functions/IFunction.cpp:593: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c81533 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:15:55.688996 [ 5085 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:15:55.766311 [ 27693 ] {4a4a2169-21b8-44af-a5db-2fc6c423438b} executeQuery: Code: 48. DB::Exception: Arguments of type FixedString are not allowed: In scope SELECT punycodeEncode(toFixedString('two', 3)). (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34114) (comment: 02932_punycode.sql) (query 11, line 20) (in query: SELECT punycodeEncode(toFixedString('two', 3));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/punycode.cpp:77: DB::PunycodeEncode::vectorFixed(DB::PODArray, 63ul, 64ul> const&, unsigned long, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x000000000e4b05db 5. /build/src/Functions/FunctionStringToString.h:81: DB::FunctionStringToString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e4afbab 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:15:55.775624 [ 27693 ] {} TCPHandler: Code: 48. DB::Exception: Arguments of type FixedString are not allowed: In scope SELECT punycodeEncode(toFixedString('two', 3)). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/punycode.cpp:77: DB::PunycodeEncode::vectorFixed(DB::PODArray, 63ul, 64ul> const&, unsigned long, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x000000000e4b05db 5. /build/src/Functions/FunctionStringToString.h:81: DB::FunctionStringToString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e4afbab 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:15:55.941834 [ 27693 ] {9fc5e6d8-9887-4271-bfda-73b8ebe93231} executeQuery: Code: 48. DB::Exception: Arguments of type FixedString are not allowed: In scope SELECT punycodeDecode(toFixedString('two', 3)). (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34114) (comment: 02932_punycode.sql) (query 12, line 21) (in query: SELECT punycodeDecode(toFixedString('two', 3));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/punycode.cpp:134: DB::PunycodeDecode<(DB::ErrorHandling)0>::vectorFixed(DB::PODArray, 63ul, 64ul> const&, unsigned long, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x000000000e4b1a7b 5. /build/src/Functions/FunctionStringToString.h:81: DB::FunctionStringToString, DB::NamePunycodeDecode, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e4b0f0b 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:15:55.950266 [ 27693 ] {} TCPHandler: Code: 48. DB::Exception: Arguments of type FixedString are not allowed: In scope SELECT punycodeDecode(toFixedString('two', 3)). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/punycode.cpp:134: DB::PunycodeDecode<(DB::ErrorHandling)0>::vectorFixed(DB::PODArray, 63ul, 64ul> const&, unsigned long, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x000000000e4b1a7b 5. /build/src/Functions/FunctionStringToString.h:81: DB::FunctionStringToString, DB::NamePunycodeDecode, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e4b0f0b 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:15:56.219840 [ 27693 ] {f7483793-d669-4fd9-8b2a-f41081bc1211} executeQuery: Code: 48. DB::Exception: Arguments of type FixedString are not allowed: In scope SELECT tryPunycodeDecode(toFixedString('two', 3)). (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34114) (comment: 02932_punycode.sql) (query 13, line 22) (in query: SELECT tryPunycodeDecode(toFixedString('two', 3));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/punycode.cpp:134: DB::PunycodeDecode<(DB::ErrorHandling)1>::vectorFixed(DB::PODArray, 63ul, 64ul> const&, unsigned long, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x000000000e4b2e7b 5. /build/src/Functions/FunctionStringToString.h:81: DB::FunctionStringToString, DB::NameTryPunycodeDecode, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e4b23ab 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:15:56.319718 [ 27693 ] {} TCPHandler: Code: 48. DB::Exception: Arguments of type FixedString are not allowed: In scope SELECT tryPunycodeDecode(toFixedString('two', 3)). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/punycode.cpp:134: DB::PunycodeDecode<(DB::ErrorHandling)1>::vectorFixed(DB::PODArray, 63ul, 64ul> const&, unsigned long, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x000000000e4b2e7b 5. /build/src/Functions/FunctionStringToString.h:81: DB::FunctionStringToString, DB::NameTryPunycodeDecode, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e4b23ab 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:15:56.334013 [ 31831 ] {5c9397dd-bee6-48bb-8b88-062b5dd749ad} executeQuery: Code: 47. DB::Exception: Compound identifier 't1.nested' cannot be resolved as table expression. In scope SELECT * FROM (SELECT 1) AS t1, t1.nested AS t2. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34124) (comment: 02385_analyzer_aliases_compound_expression.sql) (query 10, line 19) (in query: SELECT * FROM (SELECT 1) AS t1, t1.nested AS t2;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, char const*&&, String&&) @ 0x0000000013f68a8b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1278: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000013f480ee 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000013f4856d 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4364: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62ab9 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:15:56.343429 [ 31831 ] {} TCPHandler: Code: 47. DB::Exception: Compound identifier 't1.nested' cannot be resolved as table expression. In scope SELECT * FROM (SELECT 1) AS t1, t1.nested AS t2. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, char const*&&, String&&) @ 0x0000000013f68a8b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1278: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000013f480ee 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000013f4856d 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4364: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62ab9 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:15:56.467919 [ 31831 ] {41129cf9-a181-485a-9358-1f1d2c25c882} executeQuery: Code: 47. DB::Exception: Compound identifier 't1.nested' cannot be resolved as table expression. In scope SELECT * FROM t1.nested AS t2, (SELECT 1) AS t1. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34124) (comment: 02385_analyzer_aliases_compound_expression.sql) (query 11, line 21) (in query: SELECT * FROM t1.nested AS t2, (SELECT 1) AS t1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, char const*&&, String&&) @ 0x0000000013f68a8b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1278: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000013f480ee 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000013f4856d 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4364: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62ab9 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:15:56.474862 [ 31831 ] {} TCPHandler: Code: 47. DB::Exception: Compound identifier 't1.nested' cannot be resolved as table expression. In scope SELECT * FROM t1.nested AS t2, (SELECT 1) AS t1. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, char const*&&, String&&) @ 0x0000000013f68a8b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1278: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000013f480ee 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000013f4856d 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4364: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62ab9 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f31ffb 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:15:58.071739 [ 27539 ] {0f55bbac-3e79-46c9-ba73-c17c45a6b42f} 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]:34156) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Planner/PlannerJoins.cpp:1283: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x00000000148e4a3c 5. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0e7d2 6. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 7. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 10. /build/src/Interpreters/InterpreterInsertQuery.cpp:579: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001484e8a5 11. /build/src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001485221d 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 14. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 15. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 20. ? @ 0x00007f7210eb6ac3 21. ? @ 0x00007f7210f48850 2025.07.13 02:15:58.118539 [ 27539 ] {} TCPHandler: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Planner/PlannerJoins.cpp:1283: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x00000000148e4a3c 5. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0e7d2 6. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 7. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 10. /build/src/Interpreters/InterpreterInsertQuery.cpp:579: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001484e8a5 11. /build/src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001485221d 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 14. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 15. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 20. ? @ 0x00007f7210eb6ac3 21. ? @ 0x00007f7210f48850 2025.07.13 02:16:00.757731 [ 5823 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:16:01.036391 [ 3552 ] {} CgroupsReader: Cannot find 'kernel' in '/sys/fs/cgroup/memory.stat' (skipped 5543 similar messages) 2025.07.13 02:16:01.382101 [ 16758 ] {91586b2e-d809-4b03-a6c6-4d4f8bc672a4} 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]:39008) (comment: 00700_decimal_empty_aggregates.sql) (query 58, line 80) (in query: SELECT covarPop(a, a), covarPop(b, b), covarPop(c, c) FROM decimal;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x000000001002d50b 4. /build/src/AggregateFunctions/AggregateFunctionStatisticsSimple.h:266: std::shared_ptr DB::createAggregateFunctionStatisticsBinary(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000010b8db1a 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130caa1d 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:16:01.397074 [ 16758 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Decimal(6, 4) and Decimal(6, 4) of arguments for aggregate function covarPop. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x000000001002d50b 4. /build/src/AggregateFunctions/AggregateFunctionStatisticsSimple.h:266: std::shared_ptr DB::createAggregateFunctionStatisticsBinary(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000010b8db1a 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130caa1d 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:16:01.784208 [ 16758 ] {41a2bee7-33ec-47cd-92cd-6cebc25a9969} 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]:39008) (comment: 00700_decimal_empty_aggregates.sql) (query 59, line 81) (in query: SELECT covarSamp(a, a), covarSamp(b, b), covarSamp(c, c) FROM decimal;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x000000001002d50b 4. /build/src/AggregateFunctions/AggregateFunctionStatisticsSimple.h:266: std::shared_ptr DB::createAggregateFunctionStatisticsBinary(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000010b8d87a 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130caa1d 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:16:01.794136 [ 16758 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Decimal(6, 4) and Decimal(6, 4) of arguments for aggregate function covarSamp. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x000000001002d50b 4. /build/src/AggregateFunctions/AggregateFunctionStatisticsSimple.h:266: std::shared_ptr DB::createAggregateFunctionStatisticsBinary(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000010b8d87a 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130caa1d 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:16:02.082772 [ 37316 ] {cf960e74-5474-47b4-adbf-7dbe232f3d50} executeQuery: Code: 53. DB::Exception: Cannot convert string 'qEkek..' to type IntervalMinute. (TYPE_MISMATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45866) (comment: 01277_convert_field_to_type_logical_error.sql) (query 1, line 1) (in query: SELECT -2487, globalNullIn(toIntervalMinute(-88074), 'qEkek..'), [-27.537293];), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014b78237 5. /build/src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014b75587 6. /build/src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x0000000014b787c3 7. /build/src/Analyzer/SetUtils.cpp:69: DB::(anonymous namespace)::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x00000000141e85e5 8. /build/src/Analyzer/SetUtils.cpp:99: std::vector> DB::(anonymous namespace)::createBlockFromCollection(DB::Array const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, DB::GetSetElementParams) @ 0x00000000141e73ee 9. /build/src/Analyzer/SetUtils.cpp:184: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x00000000141e5a5f 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3511: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f526bd 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:16:02.095946 [ 37316 ] {} TCPHandler: Code: 53. DB::Exception: Cannot convert string 'qEkek..' to type IntervalMinute. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014b78237 5. /build/src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014b75587 6. /build/src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x0000000014b787c3 7. /build/src/Analyzer/SetUtils.cpp:69: DB::(anonymous namespace)::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x00000000141e85e5 8. /build/src/Analyzer/SetUtils.cpp:99: std::vector> DB::(anonymous namespace)::createBlockFromCollection(DB::Array const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, DB::GetSetElementParams) @ 0x00000000141e73ee 9. /build/src/Analyzer/SetUtils.cpp:184: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x00000000141e5a5f 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3511: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f526bd 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:16:02.170356 [ 16758 ] {96501c65-0db2-429f-a42b-507d31723b8d} 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]:39008) (comment: 00700_decimal_empty_aggregates.sql) (query 60, line 82) (in query: SELECT corr(a, a), corr(b, b), corr(c, c) FROM decimal;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x000000001002d50b 4. /build/src/AggregateFunctions/AggregateFunctionStatisticsSimple.h:266: std::shared_ptr DB::createAggregateFunctionStatisticsBinary(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000010c4740a 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130caa1d 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:16:02.199896 [ 16758 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Decimal(6, 4) and Decimal(6, 4) of arguments for aggregate function corr. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x000000001002d50b 4. /build/src/AggregateFunctions/AggregateFunctionStatisticsSimple.h:266: std::shared_ptr DB::createAggregateFunctionStatisticsBinary(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000010c4740a 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130caa1d 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:16:03.773550 [ 30862 ] {07224c21-3ae0-4259-bdc7-aa75009be9ae} executeQuery: Code: 47. DB::Exception: JOIN INNER JOIN ... USING (test_value) using identifier 'test_value' cannot be resolved from left table expression. In scope SELECT t1.value AS t1_value, toTypeName(t1_value), t2.value AS t2_value, toTypeName(t2_value) FROM test_table_join_1 AS t1 INNER JOIN test_table_join_2 AS t2 USING (test_value). (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34138) (comment: 02374_analyzer_join_using.gen.sql) (query 23, line 55) (in query: SELECT t1.value AS t1_value, toTypeName(t1_value), t2.value AS t2_value, toTypeName(t2_value) FROM test_table_join_1 AS t1 INNER JOIN test_table_join_2 AS t2 USING (test_value);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&, String&&) @ 0x0000000013f6a56b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5255: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f674f8 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 9. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 14. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 15. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 16. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 17. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 22. ? @ 0x00007f7210eb6ac3 23. ? @ 0x00007f7210f48850 2025.07.13 02:16:03.782003 [ 30862 ] {} TCPHandler: Code: 47. DB::Exception: JOIN INNER JOIN ... USING (test_value) using identifier 'test_value' cannot be resolved from left table expression. In scope SELECT t1.value AS t1_value, toTypeName(t1_value), t2.value AS t2_value, toTypeName(t2_value) FROM test_table_join_1 AS t1 INNER JOIN test_table_join_2 AS t2 USING (test_value). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&, String&&) @ 0x0000000013f6a56b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5255: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f674f8 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 9. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 14. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 15. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 16. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 17. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 22. ? @ 0x00007f7210eb6ac3 23. ? @ 0x00007f7210f48850 2025.07.13 02:16:04.589647 [ 27693 ] {2e96f440-d170-4917-869a-25d45273e0ca} executeQuery: Code: 36. DB::Exception: 'no punycode' is not a valid Punycode-encoded string: In scope SELECT punycodeDecode('no punycode'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34114) (comment: 02932_punycode.sql) (query 49, line 67) (in query: SELECT punycodeDecode('no punycode');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Functions/punycode.cpp:109: DB::PunycodeDecode<(DB::ErrorHandling)0>::vector(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x000000000e4b1987 5. /build/src/Functions/FunctionStringToString.h:75: DB::FunctionStringToString, DB::NamePunycodeDecode, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e4b0d4e 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:16:04.598410 [ 27693 ] {} TCPHandler: Code: 36. DB::Exception: 'no punycode' is not a valid Punycode-encoded string: In scope SELECT punycodeDecode('no punycode'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Functions/punycode.cpp:109: DB::PunycodeDecode<(DB::ErrorHandling)0>::vector(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x000000000e4b1987 5. /build/src/Functions/FunctionStringToString.h:75: DB::FunctionStringToString, DB::NamePunycodeDecode, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e4b0d4e 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:16:05.798276 [ 5085 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:16:06.122727 [ 30811 ] {988da341-6397-46c6-b4b8-45871b7d4fd5} executeQuery: Code: 57. DB::Exception: Table test_mllwl59f.t_with_dots already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45940) (comment: 02017_columns_with_dot.sql) (query 10, line 17) (in query: CREATE TABLE t_with_dots (`id` UInt32, `arr` Array(UInt32), `b.id` UInt32, `b.arr` Array(UInt32)) ENGINE = MergeTree ORDER BY id SETTINGS min_bytes_for_wide_part = 0, index_granularity = 13671, 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 = 460935009, compact_parts_max_bytes_to_buffer = 177235597, compact_parts_max_granules_to_buffer = 122, compact_parts_merge_max_bytes_to_prefetch_part = 29104649, merge_max_block_size = 17094, old_parts_lifetime = 87., prefer_fetch_merged_part_size_threshold = 4083035452, 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 = 23798693, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 98765, primary_key_compress_block_size = 9660, use_primary_key_cache = false, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:16:06.163358 [ 30811 ] {} TCPHandler: Code: 57. DB::Exception: Table test_mllwl59f.t_with_dots already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:16:07.730962 [ 30862 ] {58bb7ada-2b69-4a6c-affd-e80f77fb2f70} executeQuery: Code: 47. DB::Exception: JOIN LEFT JOIN ... USING (test_value) using identifier 'test_value' cannot be resolved from left table expression. In scope SELECT t1.value AS t1_value, toTypeName(t1_value), t2.value AS t2_value, toTypeName(t2_value) FROM test_table_join_1 AS t1 LEFT JOIN test_table_join_2 AS t2 USING (test_value). (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34138) (comment: 02374_analyzer_join_using.gen.sql) (query 30, line 75) (in query: SELECT t1.value AS t1_value, toTypeName(t1_value), t2.value AS t2_value, toTypeName(t2_value) FROM test_table_join_1 AS t1 LEFT JOIN test_table_join_2 AS t2 USING (test_value);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&, String&&) @ 0x0000000013f6a56b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5255: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f674f8 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 9. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 14. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 15. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 16. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 17. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 22. ? @ 0x00007f7210eb6ac3 23. ? @ 0x00007f7210f48850 2025.07.13 02:16:07.739347 [ 30862 ] {} TCPHandler: Code: 47. DB::Exception: JOIN LEFT JOIN ... USING (test_value) using identifier 'test_value' cannot be resolved from left table expression. In scope SELECT t1.value AS t1_value, toTypeName(t1_value), t2.value AS t2_value, toTypeName(t2_value) FROM test_table_join_1 AS t1 LEFT JOIN test_table_join_2 AS t2 USING (test_value). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&, String&&) @ 0x0000000013f6a56b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5255: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f674f8 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 9. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 14. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 15. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 16. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 17. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 22. ? @ 0x00007f7210eb6ac3 23. ? @ 0x00007f7210f48850 2025.07.13 02:16:08.182179 [ 27693 ] {c4378f1a-457b-4b2e-afa4-1cc9bcf70900} executeQuery: Code: 36. DB::Exception: 'Also no punycode' is not a valid Punycode-encoded string: while executing 'FUNCTION punycodeDecode(__table1.puny : 1) -> punycodeDecode(__table1.puny) String : 0'. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34114) (comment: 02932_punycode.sql) (query 63, line 84) (in query: SELECT puny, punycodeDecode(puny) AS original FROM tab;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Functions/punycode.cpp:109: DB::PunycodeDecode<(DB::ErrorHandling)0>::vector(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x000000000e4b1987 5. /build/src/Functions/FunctionStringToString.h:75: DB::FunctionStringToString, DB::NamePunycodeDecode, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e4b0d4e 6. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 7. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 10. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 11. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 12. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 13. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 17. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 18. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 19. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 22. ? @ 0x00007f7210eb6ac3 23. ? @ 0x00007f7210f48850 2025.07.13 02:16:08.195041 [ 30811 ] {32c6e0f7-536c-40e2-93f8-c7cd44a1135c} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 100.00. (TOO_MANY_ROWS_OR_BYTES) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45960) (comment: 01553_settings_early_apply.sql) (query 3, line 4) (in query: select * from numbers(100) settings max_result_rows = 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000013af9d2b 4. /build/src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013af96d2 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000016b4227b 6. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 7. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 10. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 11. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 12. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:16:08.197438 [ 27693 ] {} TCPHandler: Code: 36. DB::Exception: 'Also no punycode' is not a valid Punycode-encoded string: while executing 'FUNCTION punycodeDecode(__table1.puny : 1) -> punycodeDecode(__table1.puny) String : 0'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e4b1aeb 4. /build/src/Functions/punycode.cpp:109: DB::PunycodeDecode<(DB::ErrorHandling)0>::vector(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x000000000e4b1987 5. /build/src/Functions/FunctionStringToString.h:75: DB::FunctionStringToString, DB::NamePunycodeDecode, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e4b0d4e 6. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 7. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 10. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 11. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 12. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 13. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 17. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 18. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 19. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 22. ? @ 0x00007f7210eb6ac3 23. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:16:08.219572 [ 30811 ] {} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 100.00. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000013af9d2b 4. /build/src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013af96d2 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000016b4227b 6. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 7. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 10. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 11. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 12. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:16:08.323643 [ 6608 ] {956d62d9-7393-4eab-ba81-03031e5b0560} executeQuery: Code: 42. DB::Exception: Table name was not found in function arguments. Table function 'remote' requires from 1 to 6 parameters: [, , ] [, username[, password], sharding_key]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45972) (comment: 02841_remote_parameter_parsing_error.sql) (query 1, line 4) (in query: select * from remote('127.0.0.1', sys);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&&) @ 0x00000000117049ab 4. /build/src/TableFunctions/TableFunctionRemote.cpp:184: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000011701e0a 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3bbcc 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:16:08.348642 [ 6608 ] {} TCPHandler: Code: 42. DB::Exception: Table name was not found in function arguments. Table function 'remote' requires from 1 to 6 parameters: [, , ] [, username[, password], sharding_key]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&&) @ 0x00000000117049ab 4. /build/src/TableFunctions/TableFunctionRemote.cpp:184: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000011701e0a 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3bbcc 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:16:08.461026 [ 30811 ] {fc3b4bcc-4ca4-4119-9333-c45296e49bf0} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 100.00. (TOO_MANY_ROWS_OR_BYTES) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45960) (comment: 01553_settings_early_apply.sql) (query 4, line 5) (in query: select * from numbers(100) FORMAT JSON settings max_result_rows = 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000013af9d2b 4. /build/src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013af96d2 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000016b4227b 6. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 7. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 10. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 11. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 12. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:16:08.489641 [ 30811 ] {} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 100.00. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000013af9d2b 4. /build/src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013af96d2 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000016b4227b 6. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 7. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 10. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 11. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 12. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:16:08.544118 [ 6608 ] {f908c3d8-698b-4934-8b4d-8ba21b6b5464} executeQuery: Code: 42. DB::Exception: Table name was not found in function arguments. Table function 'remote' requires from 1 to 6 parameters: [, , ] [, username[, password], sharding_key]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45972) (comment: 02841_remote_parameter_parsing_error.sql) (query 2, line 5) (in query: select * from remote('127.0.0.1', system);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&&) @ 0x00000000117049ab 4. /build/src/TableFunctions/TableFunctionRemote.cpp:184: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000011701e0a 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3bbcc 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:16:08.575395 [ 6608 ] {} TCPHandler: Code: 42. DB::Exception: Table name was not found in function arguments. Table function 'remote' requires from 1 to 6 parameters: [, , ] [, username[, password], sharding_key]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&&) @ 0x00000000117049ab 4. /build/src/TableFunctions/TableFunctionRemote.cpp:184: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000011701e0a 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3bbcc 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:16:08.759799 [ 30811 ] {e2d44fcc-689c-4c3a-b98f-8ca7a67bffc5} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 100.00. (TOO_MANY_ROWS_OR_BYTES) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45960) (comment: 01553_settings_early_apply.sql) (query 5, line 6) (in query: select * from numbers(100) FORMAT TSVWithNamesAndTypes settings max_result_rows = 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000013af9d2b 4. /build/src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013af96d2 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000016b4227b 6. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 7. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 10. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 11. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 12. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:16:08.778622 [ 30811 ] {} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 100.00. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000013af9d2b 4. /build/src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013af96d2 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000016b4227b 6. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 7. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 10. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 11. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 12. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:16:08.889007 [ 6608 ] {6d98ff65-9fb6-4837-b6c0-1cbfbc0ce43d} executeQuery: Code: 60. DB::Exception: Table system.o does not exist. Maybe you meant test_13.t?. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45972) (comment: 02841_remote_parameter_parsing_error.sql) (query 3, line 6) (in query: select * from remote('127.0.0.1', system.o);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x000000000a04526b 4. /build/src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013cf9caa 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144148c9 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001441ace8 7. /build/src/Storages/getStructureOfRemoteTable.cpp:61: DB::getStructureOfRemoteTableInShard(DB::Cluster const&, DB::Cluster::ShardInfo const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x0000000015f760bb 8. /build/src/Storages/getStructureOfRemoteTable.cpp:150: DB::getStructureOfRemoteTable(DB::Cluster const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x0000000015f78392 9. /build/src/TableFunctions/TableFunctionRemote.cpp:337: DB::TableFunctionRemote::getActualTableStructure(std::shared_ptr, bool) const @ 0x00000000117030ab 10. /build/src/TableFunctions/TableFunctionRemote.cpp:309: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000117028c0 11. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000130d4903 12. /build/src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000143537f2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3da49 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 25. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 26. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 31. ? @ 0x00007f7210eb6ac3 2025.07.13 02:16:08.920885 [ 6608 ] {} TCPHandler: Code: 60. DB::Exception: Table system.o does not exist. Maybe you meant test_13.t?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x000000000a04526b 4. /build/src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013cf9caa 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144148c9 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001441ace8 7. /build/src/Storages/getStructureOfRemoteTable.cpp:61: DB::getStructureOfRemoteTableInShard(DB::Cluster const&, DB::Cluster::ShardInfo const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x0000000015f760bb 8. /build/src/Storages/getStructureOfRemoteTable.cpp:150: DB::getStructureOfRemoteTable(DB::Cluster const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x0000000015f78392 9. /build/src/TableFunctions/TableFunctionRemote.cpp:337: DB::TableFunctionRemote::getActualTableStructure(std::shared_ptr, bool) const @ 0x00000000117030ab 10. /build/src/TableFunctions/TableFunctionRemote.cpp:309: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000117028c0 11. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000130d4903 12. /build/src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000143537f2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3da49 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 25. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 26. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 31. ? @ 0x00007f7210eb6ac3 2025.07.13 02:16:08.997646 [ 30811 ] {baceb462-f887-4c84-9f1b-6556ae22768e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=858, jobs=843). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45960) (comment: 01553_settings_early_apply.sql) (query 6, line 7) (in query: select * from numbers(100) FORMAT CSVWithNamesAndTypes settings max_result_rows = 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbdd1d3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd751c 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 9. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 10. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:16:09.026644 [ 30811 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=858, jobs=843). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbdd1d3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd751c 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 9. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 10. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:16:09.170956 [ 6608 ] {63bdae65-5913-4ef8-9198-8a83c0c2b84c} executeQuery: Code: 47. DB::Exception: Missing columns: 'default' while processing: 'default', required columns: 'default', available columns: 'dummy'. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45972) (comment: 02841_remote_parameter_parsing_error.sql) (query 4, line 7) (in query: select * from remote('127.0.0.1', system.one, default);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Interpreters/TreeRewriter.cpp:1303: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x0000000014b1fec8 4. /build/src/Interpreters/TreeRewriter.cpp:1561: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x0000000014b28338 5. /build/src/Storages/StorageDistributed.cpp:265: DB::(anonymous namespace)::buildShardingKeyExpression(std::shared_ptr const&, std::shared_ptr, DB::NamesAndTypesList const&, bool) @ 0x0000000015c7e228 6. /build/src/Storages/StorageDistributed.cpp:408: DB::StorageDistributed::StorageDistributed(DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, String const&, String const&, std::shared_ptr, std::shared_ptr const&, String const&, String const&, DB::DistributedSettings const&, DB::LoadingStrictnessLevel, std::shared_ptr, std::shared_ptr, bool) @ 0x0000000015c7cbcd 7. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, String const&, String const&, String, std::shared_ptr&, std::shared_ptr const&, String, String, DB::DistributedSettings, DB::LoadingStrictnessLevel, std::shared_ptr const&, std::shared_ptr const&, bool, 0>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, String const&, String const&, String&&, std::shared_ptr&, std::shared_ptr const&, String&&, String&&, DB::DistributedSettings&&, DB::LoadingStrictnessLevel&&, std::shared_ptr const&, std::shared_ptr const&, bool&&) @ 0x0000000011706ae9 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000011702c30 9. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000130d4903 10. /build/src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000143537f2 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3da49 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:16:09.219849 [ 6608 ] {} TCPHandler: Code: 47. DB::Exception: Missing columns: 'default' while processing: 'default', required columns: 'default', available columns: 'dummy'. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Interpreters/TreeRewriter.cpp:1303: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x0000000014b1fec8 4. /build/src/Interpreters/TreeRewriter.cpp:1561: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x0000000014b28338 5. /build/src/Storages/StorageDistributed.cpp:265: DB::(anonymous namespace)::buildShardingKeyExpression(std::shared_ptr const&, std::shared_ptr, DB::NamesAndTypesList const&, bool) @ 0x0000000015c7e228 6. /build/src/Storages/StorageDistributed.cpp:408: DB::StorageDistributed::StorageDistributed(DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, String const&, String const&, std::shared_ptr, std::shared_ptr const&, String const&, String const&, DB::DistributedSettings const&, DB::LoadingStrictnessLevel, std::shared_ptr, std::shared_ptr, bool) @ 0x0000000015c7cbcd 7. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, String const&, String const&, String, std::shared_ptr&, std::shared_ptr const&, String, String, DB::DistributedSettings, DB::LoadingStrictnessLevel, std::shared_ptr const&, std::shared_ptr const&, bool, 0>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, String const&, String const&, String&&, std::shared_ptr&, std::shared_ptr const&, String&&, String&&, DB::DistributedSettings&&, DB::LoadingStrictnessLevel&&, std::shared_ptr const&, std::shared_ptr const&, bool&&) @ 0x0000000011706ae9 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000011702c30 9. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000130d4903 10. /build/src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000143537f2 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3da49 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:16:09.506607 [ 6608 ] {945c64de-3309-4e68-9e5d-fc93adf1a96b} executeQuery: Code: 36. DB::Exception: Arguments `user` and `password` should be string literals (in single quotes). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45972) (comment: 02841_remote_parameter_parsing_error.sql) (query 5, line 8) (in query: SELECT * FROM remote('127.0.0.1', system.one, default, '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/TableFunctions/TableFunctionRemote.cpp:230: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000011701d3d 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3bbcc 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:16:09.525368 [ 6608 ] {} TCPHandler: Code: 36. DB::Exception: Arguments `user` and `password` should be string literals (in single quotes). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/TableFunctions/TableFunctionRemote.cpp:230: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000011701d3d 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3bbcc 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:16:09.698684 [ 6608 ] {edce3cca-986e-4a96-ac52-ab8594a78a6a} executeQuery: Code: 36. DB::Exception: Arguments `user` and `password` should be string literals (in single quotes). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45972) (comment: 02841_remote_parameter_parsing_error.sql) (query 6, line 9) (in query: select * from remote('127.0.0.1', system.one, default, key1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/TableFunctions/TableFunctionRemote.cpp:230: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000011701d3d 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3bbcc 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:16:09.712965 [ 6608 ] {} TCPHandler: Code: 36. DB::Exception: Arguments `user` and `password` should be string literals (in single quotes). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/TableFunctions/TableFunctionRemote.cpp:230: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000011701d3d 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3bbcc 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:16:09.924878 [ 6608 ] {dc63f00e-1bc2-413f-9dbb-2836c0345b42} executeQuery: Code: 47. DB::Exception: Missing columns: 'key1' while processing: 'key1', required columns: 'key1', available columns: 'dummy'. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45972) (comment: 02841_remote_parameter_parsing_error.sql) (query 7, line 10) (in query: SELECT * FROM remote('127.0.0.1', system.one, 'default', '[HIDDEN]', key1)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Interpreters/TreeRewriter.cpp:1303: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x0000000014b1fec8 4. /build/src/Interpreters/TreeRewriter.cpp:1561: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x0000000014b28338 5. /build/src/Storages/StorageDistributed.cpp:265: DB::(anonymous namespace)::buildShardingKeyExpression(std::shared_ptr const&, std::shared_ptr, DB::NamesAndTypesList const&, bool) @ 0x0000000015c7e228 6. /build/src/Storages/StorageDistributed.cpp:408: DB::StorageDistributed::StorageDistributed(DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, String const&, String const&, std::shared_ptr, std::shared_ptr const&, String const&, String const&, DB::DistributedSettings const&, DB::LoadingStrictnessLevel, std::shared_ptr, std::shared_ptr, bool) @ 0x0000000015c7cbcd 7. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, String const&, String const&, String, std::shared_ptr&, std::shared_ptr const&, String, String, DB::DistributedSettings, DB::LoadingStrictnessLevel, std::shared_ptr const&, std::shared_ptr const&, bool, 0>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, String const&, String const&, String&&, std::shared_ptr&, std::shared_ptr const&, String&&, String&&, DB::DistributedSettings&&, DB::LoadingStrictnessLevel&&, std::shared_ptr const&, std::shared_ptr const&, bool&&) @ 0x0000000011706ae9 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000011702c30 9. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000130d4903 10. /build/src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000143537f2 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3da49 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:16:09.936018 [ 6608 ] {} TCPHandler: Code: 47. DB::Exception: Missing columns: 'key1' while processing: 'key1', required columns: 'key1', available columns: 'dummy'. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Interpreters/TreeRewriter.cpp:1303: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x0000000014b1fec8 4. /build/src/Interpreters/TreeRewriter.cpp:1561: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x0000000014b28338 5. /build/src/Storages/StorageDistributed.cpp:265: DB::(anonymous namespace)::buildShardingKeyExpression(std::shared_ptr const&, std::shared_ptr, DB::NamesAndTypesList const&, bool) @ 0x0000000015c7e228 6. /build/src/Storages/StorageDistributed.cpp:408: DB::StorageDistributed::StorageDistributed(DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, String const&, String const&, std::shared_ptr, std::shared_ptr const&, String const&, String const&, DB::DistributedSettings const&, DB::LoadingStrictnessLevel, std::shared_ptr, std::shared_ptr, bool) @ 0x0000000015c7cbcd 7. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, String const&, String const&, String, std::shared_ptr&, std::shared_ptr const&, String, String, DB::DistributedSettings, DB::LoadingStrictnessLevel, std::shared_ptr const&, std::shared_ptr const&, bool, 0>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, String const&, String const&, String&&, std::shared_ptr&, std::shared_ptr const&, String&&, String&&, DB::DistributedSettings&&, DB::LoadingStrictnessLevel&&, std::shared_ptr const&, std::shared_ptr const&, bool&&) @ 0x0000000011706ae9 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000011702c30 9. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000130d4903 10. /build/src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000143537f2 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3da49 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:16:10.045994 [ 30860 ] {1a04495b-bd82-4533-b477-1a414fbe2785} executeQuery: Code: 6. DB::Exception: Cannot parse string 'Test' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: In scope WITH map(1, 'Test') AS value, 'Array(Tuple(UInt64, UInt64))' AS type SELECT value, CAST(value, type), CAST(materialize(value), type). (CANNOT_PARSE_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45576) (comment: 02179_map_cast_to_array.sql) (query 2, line 4) (in query: WITH map(1, 'Test') AS value, 'Array(Tuple(UInt64, UInt64))' AS type SELECT value, cast(value, type), cast(materialize(value), type);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000012ee0fca 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl, DB::detail::NameToUInt64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000012ee0cbe 6. /build/src/Functions/FunctionsConversion.h:2472: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e88344 7. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012e9ce8e 8. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012e9c6ba 9. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 10. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Functions/IFunction.cpp:513: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c80999 14. /build/src/Functions/FunctionsConversion.h:3487: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000012ceb2d6 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012e6a232 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] const&, DB::DataTypeTuple const*) const::'lambda0'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000012e69d8c 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012e68cca 18. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] const&, DB::DataTypeArray const&) const::'lambda0'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000012e68a2c 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012cc745b 20. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fc534a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f75b 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:16:10.056519 [ 6608 ] {4ce0e2be-1a54-405d-8b97-75be4797fb70} executeQuery: Code: 36. DB::Exception: Arguments `user` and `password` should be string literals (in single quotes). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45972) (comment: 02841_remote_parameter_parsing_error.sql) (query 8, line 11) (in query: SELECT * FROM remote('127.0.0.1', system.one, default, '[HIDDEN]', key1)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/TableFunctions/TableFunctionRemote.cpp:230: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000011701d3d 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3bbcc 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:16:10.061255 [ 30860 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string 'Test' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: In scope WITH map(1, 'Test') AS value, 'Array(Tuple(UInt64, UInt64))' AS type SELECT value, CAST(value, type), CAST(materialize(value), type). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000012ee0fca 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl, DB::detail::NameToUInt64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000012ee0cbe 6. /build/src/Functions/FunctionsConversion.h:2472: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e88344 7. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012e9ce8e 8. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012e9c6ba 9. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 10. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Functions/IFunction.cpp:513: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c80999 14. /build/src/Functions/FunctionsConversion.h:3487: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000012ceb2d6 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012e6a232 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] const&, DB::DataTypeTuple const*) const::'lambda0'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000012e69d8c 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012e68cca 18. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] const&, DB::DataTypeArray const&) const::'lambda0'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000012e68a2c 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012cc745b 20. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fc534a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 24. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f75b 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 2025.07.13 02:16:10.065071 [ 6608 ] {} TCPHandler: Code: 36. DB::Exception: Arguments `user` and `password` should be string literals (in single quotes). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/TableFunctions/TableFunctionRemote.cpp:230: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000011701d3d 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3bbcc 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:16:10.238529 [ 6608 ] {d956a54e-1a47-4f01-bc1b-b3ff1045319b} executeQuery: Code: 36. DB::Exception: Arguments `user` and `password` should be string literals (in single quotes). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45972) (comment: 02841_remote_parameter_parsing_error.sql) (query 9, line 12) (in query: select * from remote('127.0.0.1', system.one, 'default', pwd, key1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/TableFunctions/TableFunctionRemote.cpp:230: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000011701d3d 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3bbcc 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:16:10.248867 [ 6608 ] {} TCPHandler: Code: 36. DB::Exception: Arguments `user` and `password` should be string literals (in single quotes). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/TableFunctions/TableFunctionRemote.cpp:230: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000011701d3d 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3bbcc 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:16:10.426638 [ 6608 ] {6ab3ed11-9d78-41b0-8138-22b29ad714d8} executeQuery: Code: 42. DB::Exception: Table function 'remote' requires from 1 to 6 parameters: [, , ] [, username[, password], sharding_key]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45972) (comment: 02841_remote_parameter_parsing_error.sql) (query 10, line 13) (in query: SELECT * FROM remote('127.0.0.1', system.one, 'default', '[HIDDEN]', key1, key2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x0000000011703ecc 3. /build/src/TableFunctions/TableFunctionRemote.cpp:238: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000011701b5d 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3bbcc 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 9. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 14. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 15. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 16. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 17. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 22. ? @ 0x00007f7210eb6ac3 23. ? @ 0x00007f7210f48850 2025.07.13 02:16:10.436753 [ 6608 ] {} TCPHandler: Code: 42. DB::Exception: Table function 'remote' requires from 1 to 6 parameters: [, , ] [, username[, password], sharding_key]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x0000000011703ecc 3. /build/src/TableFunctions/TableFunctionRemote.cpp:238: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000011701b5d 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3bbcc 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 9. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 14. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 15. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 16. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 17. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 22. ? @ 0x00007f7210eb6ac3 23. ? @ 0x00007f7210f48850 2025.07.13 02:16:10.627076 [ 6608 ] {dfedf29d-5049-4162-a239-3e9104799105} executeQuery: Code: 42. DB::Exception: Table function 'remote' requires from 1 to 6 parameters: [, , ] [, username[, password], sharding_key]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45972) (comment: 02841_remote_parameter_parsing_error.sql) (query 11, line 14) (in query: SELECT * FROM remote('127.0.0.1', system, one, 'default', '[HIDDEN]', key1, key2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x0000000011703ecc 3. /build/src/TableFunctions/TableFunctionRemote.cpp:124: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000011701b33 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3bbcc 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 9. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 14. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 15. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 16. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 17. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 22. ? @ 0x00007f7210eb6ac3 23. ? @ 0x00007f7210f48850 2025.07.13 02:16:10.645572 [ 6608 ] {} TCPHandler: Code: 42. DB::Exception: Table function 'remote' requires from 1 to 6 parameters: [, , ] [, username[, password], sharding_key]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x0000000011703ecc 3. /build/src/TableFunctions/TableFunctionRemote.cpp:124: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000011701b33 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3bbcc 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 9. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 14. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 15. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 16. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 17. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 22. ? @ 0x00007f7210eb6ac3 23. ? @ 0x00007f7210f48850 2025.07.13 02:16:10.895259 [ 11525 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:16:11.539223 [ 4922 ] {cf82336a-dcfd-48fa-881c-0500e50539b3} executeQuery: Code: 60. DB::Exception: Could not find table: t22. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45612) (comment: 03325_alter_ast_format.sql) (query 1, line 1) (in query: -- https://github.com/ClickHouse/ClickHouse/issues/74369 -- Note that this is fixed by enabling format_alter_operations_with_parentheses. Otherwise in debug mode it'd throw a LOGICAL_ERROR ALTER TABLE t22 (DELETE WHERE ('å«' = c1) OR ((792.3673220441809 = c0) AND (c0 = c1))), (MODIFY SETTING persistent = 1), (UPDATE c1 = 'would' WHERE NOT f2()), (MODIFY SETTING persistent = 0);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fdd59 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:16:11.552619 [ 4922 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: t22. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fdd59 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 8. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 9. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:16:12.107878 [ 30862 ] {db04172b-10ee-493b-8439-4dfc62d4f335} executeQuery: Code: 47. DB::Exception: JOIN RIGHT JOIN ... USING (test_value) using identifier 'test_value' cannot be resolved from left table expression. In scope SELECT t1.value AS t1_value, toTypeName(t1_value), t2.value AS t2_value, toTypeName(t2_value) FROM test_table_join_1 AS t1 RIGHT JOIN test_table_join_2 AS t2 USING (test_value). (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34138) (comment: 02374_analyzer_join_using.gen.sql) (query 37, line 95) (in query: SELECT t1.value AS t1_value, toTypeName(t1_value), t2.value AS t2_value, toTypeName(t2_value) FROM test_table_join_1 AS t1 RIGHT JOIN test_table_join_2 AS t2 USING (test_value);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&, String&&) @ 0x0000000013f6a56b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5255: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f674f8 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 9. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 14. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 15. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 16. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 17. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 22. ? @ 0x00007f7210eb6ac3 23. ? @ 0x00007f7210f48850 2025.07.13 02:16:12.127843 [ 30862 ] {} TCPHandler: Code: 47. DB::Exception: JOIN RIGHT JOIN ... USING (test_value) using identifier 'test_value' cannot be resolved from left table expression. In scope SELECT t1.value AS t1_value, toTypeName(t1_value), t2.value AS t2_value, toTypeName(t2_value) FROM test_table_join_1 AS t1 RIGHT JOIN test_table_join_2 AS t2 USING (test_value). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&, String&&) @ 0x0000000013f6a56b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5255: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f674f8 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 9. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 14. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 15. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 16. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 17. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 22. ? @ 0x00007f7210eb6ac3 23. ? @ 0x00007f7210f48850 2025.07.13 02:16:12.235120 [ 4888 ] {dd9b41fc-ad82-4fd6-ac29-1387a396ed5c} executeQuery: Code: 159. DB::Exception: Timeout exceeded (180 s) while flushing system log 'DB::SystemLogQueue'. (TIMEOUT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:50482) (comment: 03310_create_database_with_settings.sql) (query 3, line 3) (in query: SYSTEM FLUSH LOGS;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Common/SystemLogBase.cpp:168: DB::SystemLogQueue::waitFlush(long, bool) @ 0x000000000fbee407 5. /build/src/Interpreters/SystemLog.cpp:437: DB::SystemLogs::flush(bool, std::vector> const&) @ 0x0000000014a1ea9f 6. /build/src/Interpreters/InterpreterSystemQuery.cpp:796: DB::InterpreterSystemQuery::execute() @ 0x0000000014bd5a4e 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:16:12.259681 [ 4888 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded (180 s) while flushing system log 'DB::SystemLogQueue'. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Common/SystemLogBase.cpp:168: DB::SystemLogQueue::waitFlush(long, bool) @ 0x000000000fbee407 5. /build/src/Interpreters/SystemLog.cpp:437: DB::SystemLogs::flush(bool, std::vector> const&) @ 0x0000000014a1ea9f 6. /build/src/Interpreters/InterpreterSystemQuery.cpp:796: DB::InterpreterSystemQuery::execute() @ 0x0000000014bd5a4e 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:16:13.840381 [ 4922 ] {a4dbc7ea-607c-4b31-8abc-30a421e1e660} executeQuery: Code: 36. DB::Exception: Filesystem cache path must lie inside `/var/lib/clickhouse/filesystem_caches/` (for disk: __tmp_internal_192572865902391155738371101882021692813): While processing disk(type = cache, max_size = '1Mi', path = '/kek', disk = 'local_disk'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45618) (comment: 02842_filesystem_cache_validate_path.sql) (query 4, line 7) (in query: CREATE TABLE test (`a` Int32) ENGINE = MergeTree ORDER BY tuple() SETTINGS disk = disk(type = cache, max_size = '1Mi', path = '/kek', disk = 'local_disk'), index_granularity = 47406, min_bytes_for_wide_part = 156516137, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 328653552, compact_parts_max_granules_to_buffer = 156, compact_parts_merge_max_bytes_to_prefetch_part = 978169, merge_max_block_size = 19696, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 6425393419, 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 = 20990204, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 56, 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 = 15256, primary_key_compress_block_size = 18921, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String const&) @ 0x000000000fd242eb 4. /build/src/Disks/ObjectStorages/Cached/registerDiskCache.cpp:87: DB::registerDiskCache(DB::DiskFactory&, bool)::$_0::operator()(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool) const @ 0x0000000013e0805e 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013dce296 6. /build/src/Disks/DiskFromAST.cpp:57: std::shared_ptr std::__function::__policy_invoker (std::map, std::less, std::allocator>>> const&)>::__call_impl[abi:se190107], 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&) @ 0x0000000016431a50 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000143667ec 8. /build/src/Disks/DiskFromAST.cpp:56: DB::getOrCreateCustomDisk(Poco::AutoPtr, String const&, std::shared_ptr, bool) @ 0x0000000016430dd7 9. /build/src/Disks/DiskFromAST.cpp:117: DB::DiskConfigurationFlattener::visit(std::shared_ptr&, DB::DiskConfigurationFlattener::Data&) @ 0x0000000016431f3c 10. /build/src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x0000000016431db5 11. /build/src/Interpreters/InDepthNodeVisitor.h:61: DB::DiskFromAST::createCustomDisk(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000164316ca 12. /build/src/Storages/MergeTree/MergeTreeSettings.cpp:398: DB::MergeTreeSettingsImpl::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x0000000016403b69 13. /build/src/Storages/MergeTree/MergeTreeSettings.cpp:714: DB::MergeTreeSettings::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x0000000016406404 14. /build/src/Storages/MergeTree/registerStorageMergeTree.cpp:705: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000165521de 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ca1a22 16. /build/src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001481ee32 17. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 18. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 19. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:16:13.879520 [ 4922 ] {} TCPHandler: Code: 36. DB::Exception: Filesystem cache path must lie inside `/var/lib/clickhouse/filesystem_caches/` (for disk: __tmp_internal_192572865902391155738371101882021692813): While processing disk(type = cache, max_size = '1Mi', path = '/kek', disk = 'local_disk'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String const&) @ 0x000000000fd242eb 4. /build/src/Disks/ObjectStorages/Cached/registerDiskCache.cpp:87: DB::registerDiskCache(DB::DiskFactory&, bool)::$_0::operator()(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool) const @ 0x0000000013e0805e 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013dce296 6. /build/src/Disks/DiskFromAST.cpp:57: std::shared_ptr std::__function::__policy_invoker (std::map, std::less, std::allocator>>> const&)>::__call_impl[abi:se190107], 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&) @ 0x0000000016431a50 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000143667ec 8. /build/src/Disks/DiskFromAST.cpp:56: DB::getOrCreateCustomDisk(Poco::AutoPtr, String const&, std::shared_ptr, bool) @ 0x0000000016430dd7 9. /build/src/Disks/DiskFromAST.cpp:117: DB::DiskConfigurationFlattener::visit(std::shared_ptr&, DB::DiskConfigurationFlattener::Data&) @ 0x0000000016431f3c 10. /build/src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x0000000016431db5 11. /build/src/Interpreters/InDepthNodeVisitor.h:61: DB::DiskFromAST::createCustomDisk(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000164316ca 12. /build/src/Storages/MergeTree/MergeTreeSettings.cpp:398: DB::MergeTreeSettingsImpl::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x0000000016403b69 13. /build/src/Storages/MergeTree/MergeTreeSettings.cpp:714: DB::MergeTreeSettings::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x0000000016406404 14. /build/src/Storages/MergeTree/registerStorageMergeTree.cpp:705: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000165521de 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ca1a22 16. /build/src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001481ee32 17. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 18. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 19. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:16:13.903519 [ 6608 ] {07d9cb3a-49cc-4b57-baf6-add52864e657} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=858, jobs=837). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45598) (comment: 00192_least_greatest.sql) (query 8, line 8) (in query: SELECT 123 AS x, 123 AS y, least(x, y), greatest(x, y), least(x, materialize(y)), greatest(materialize(x), y), greatest(materialize(x), materialize(y)), toTypeName(least(x, y));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbdd1d3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd751c 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 9. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 10. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:16:13.938947 [ 6608 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=858, jobs=837). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbdd1d3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd751c 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 9. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 10. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:16:14.143514 [ 4922 ] {ca9159aa-cf93-4f5a-b413-016847cc4d16} executeQuery: Code: 36. DB::Exception: Filesystem cache path must lie inside `/var/lib/clickhouse/filesystem_caches/` (for disk: __tmp_internal_262870538002818487146265108116777811907): While processing disk(type = cache, max_size = '1Mi', path = '/var/lib/clickhouse/filesystem_caches/../kek', disk = 'local_disk'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45618) (comment: 02842_filesystem_cache_validate_path.sql) (query 5, line 15) (in query: CREATE TABLE test (`a` Int32) ENGINE = MergeTree ORDER BY tuple() SETTINGS disk = disk(type = cache, max_size = '1Mi', path = '/var/lib/clickhouse/filesystem_caches/../kek', disk = 'local_disk'), index_granularity = 47406, min_bytes_for_wide_part = 156516137, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 328653552, compact_parts_max_granules_to_buffer = 156, compact_parts_merge_max_bytes_to_prefetch_part = 978169, merge_max_block_size = 19696, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 6425393419, 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 = 20990204, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 56, 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 = 15256, primary_key_compress_block_size = 18921, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String const&) @ 0x000000000fd242eb 4. /build/src/Disks/ObjectStorages/Cached/registerDiskCache.cpp:87: DB::registerDiskCache(DB::DiskFactory&, bool)::$_0::operator()(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool) const @ 0x0000000013e0805e 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013dce296 6. /build/src/Disks/DiskFromAST.cpp:57: std::shared_ptr std::__function::__policy_invoker (std::map, std::less, std::allocator>>> const&)>::__call_impl[abi:se190107], 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&) @ 0x0000000016431a50 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000143667ec 8. /build/src/Disks/DiskFromAST.cpp:56: DB::getOrCreateCustomDisk(Poco::AutoPtr, String const&, std::shared_ptr, bool) @ 0x0000000016430dd7 9. /build/src/Disks/DiskFromAST.cpp:117: DB::DiskConfigurationFlattener::visit(std::shared_ptr&, DB::DiskConfigurationFlattener::Data&) @ 0x0000000016431f3c 10. /build/src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x0000000016431db5 11. /build/src/Interpreters/InDepthNodeVisitor.h:61: DB::DiskFromAST::createCustomDisk(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000164316ca 12. /build/src/Storages/MergeTree/MergeTreeSettings.cpp:398: DB::MergeTreeSettingsImpl::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x0000000016403b69 13. /build/src/Storages/MergeTree/MergeTreeSettings.cpp:714: DB::MergeTreeSettings::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x0000000016406404 14. /build/src/Storages/MergeTree/registerStorageMergeTree.cpp:705: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000165521de 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ca1a22 16. /build/src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001481ee32 17. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 18. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 19. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:16:14.158551 [ 4922 ] {} TCPHandler: Code: 36. DB::Exception: Filesystem cache path must lie inside `/var/lib/clickhouse/filesystem_caches/` (for disk: __tmp_internal_262870538002818487146265108116777811907): While processing disk(type = cache, max_size = '1Mi', path = '/var/lib/clickhouse/filesystem_caches/../kek', disk = 'local_disk'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String const&) @ 0x000000000fd242eb 4. /build/src/Disks/ObjectStorages/Cached/registerDiskCache.cpp:87: DB::registerDiskCache(DB::DiskFactory&, bool)::$_0::operator()(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool) const @ 0x0000000013e0805e 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013dce296 6. /build/src/Disks/DiskFromAST.cpp:57: std::shared_ptr std::__function::__policy_invoker (std::map, std::less, std::allocator>>> const&)>::__call_impl[abi:se190107], 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&) @ 0x0000000016431a50 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000143667ec 8. /build/src/Disks/DiskFromAST.cpp:56: DB::getOrCreateCustomDisk(Poco::AutoPtr, String const&, std::shared_ptr, bool) @ 0x0000000016430dd7 9. /build/src/Disks/DiskFromAST.cpp:117: DB::DiskConfigurationFlattener::visit(std::shared_ptr&, DB::DiskConfigurationFlattener::Data&) @ 0x0000000016431f3c 10. /build/src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x0000000016431db5 11. /build/src/Interpreters/InDepthNodeVisitor.h:61: DB::DiskFromAST::createCustomDisk(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000164316ca 12. /build/src/Storages/MergeTree/MergeTreeSettings.cpp:398: DB::MergeTreeSettingsImpl::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x0000000016403b69 13. /build/src/Storages/MergeTree/MergeTreeSettings.cpp:714: DB::MergeTreeSettings::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x0000000016406404 14. /build/src/Storages/MergeTree/registerStorageMergeTree.cpp:705: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000165521de 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ca1a22 16. /build/src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001481ee32 17. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 18. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 19. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:16:14.383930 [ 4922 ] {59bde71e-a7d0-433e-b167-52994ee2f4b5} executeQuery: Code: 36. DB::Exception: Filesystem cache path must lie inside `/var/lib/clickhouse/filesystem_caches/` (for disk: __tmp_internal_58561455282842823620715320733810034789): While processing disk(type = cache, max_size = '1Mi', path = '../kek', disk = 'local_disk'). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45618) (comment: 02842_filesystem_cache_validate_path.sql) (query 6, line 23) (in query: CREATE TABLE test (`a` Int32) ENGINE = MergeTree ORDER BY tuple() SETTINGS disk = disk(type = cache, max_size = '1Mi', path = '../kek', disk = 'local_disk'), index_granularity = 47406, min_bytes_for_wide_part = 156516137, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 328653552, compact_parts_max_granules_to_buffer = 156, compact_parts_merge_max_bytes_to_prefetch_part = 978169, merge_max_block_size = 19696, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 6425393419, 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 = 20990204, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 56, 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 = 15256, primary_key_compress_block_size = 18921, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String const&) @ 0x000000000fd242eb 4. /build/src/Disks/ObjectStorages/Cached/registerDiskCache.cpp:87: DB::registerDiskCache(DB::DiskFactory&, bool)::$_0::operator()(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool) const @ 0x0000000013e0805e 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013dce296 6. /build/src/Disks/DiskFromAST.cpp:57: std::shared_ptr std::__function::__policy_invoker (std::map, std::less, std::allocator>>> const&)>::__call_impl[abi:se190107], 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&) @ 0x0000000016431a50 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000143667ec 8. /build/src/Disks/DiskFromAST.cpp:56: DB::getOrCreateCustomDisk(Poco::AutoPtr, String const&, std::shared_ptr, bool) @ 0x0000000016430dd7 9. /build/src/Disks/DiskFromAST.cpp:117: DB::DiskConfigurationFlattener::visit(std::shared_ptr&, DB::DiskConfigurationFlattener::Data&) @ 0x0000000016431f3c 10. /build/src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x0000000016431db5 11. /build/src/Interpreters/InDepthNodeVisitor.h:61: DB::DiskFromAST::createCustomDisk(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000164316ca 12. /build/src/Storages/MergeTree/MergeTreeSettings.cpp:398: DB::MergeTreeSettingsImpl::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x0000000016403b69 13. /build/src/Storages/MergeTree/MergeTreeSettings.cpp:714: DB::MergeTreeSettings::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x0000000016406404 14. /build/src/Storages/MergeTree/registerStorageMergeTree.cpp:705: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000165521de 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ca1a22 16. /build/src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001481ee32 17. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 18. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 19. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:16:14.421185 [ 4922 ] {} TCPHandler: Code: 36. DB::Exception: Filesystem cache path must lie inside `/var/lib/clickhouse/filesystem_caches/` (for disk: __tmp_internal_58561455282842823620715320733810034789): While processing disk(type = cache, max_size = '1Mi', path = '../kek', disk = 'local_disk'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String const&) @ 0x000000000fd242eb 4. /build/src/Disks/ObjectStorages/Cached/registerDiskCache.cpp:87: DB::registerDiskCache(DB::DiskFactory&, bool)::$_0::operator()(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool) const @ 0x0000000013e0805e 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013dce296 6. /build/src/Disks/DiskFromAST.cpp:57: std::shared_ptr std::__function::__policy_invoker (std::map, std::less, std::allocator>>> const&)>::__call_impl[abi:se190107], 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&) @ 0x0000000016431a50 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000143667ec 8. /build/src/Disks/DiskFromAST.cpp:56: DB::getOrCreateCustomDisk(Poco::AutoPtr, String const&, std::shared_ptr, bool) @ 0x0000000016430dd7 9. /build/src/Disks/DiskFromAST.cpp:117: DB::DiskConfigurationFlattener::visit(std::shared_ptr&, DB::DiskConfigurationFlattener::Data&) @ 0x0000000016431f3c 10. /build/src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x0000000016431db5 11. /build/src/Interpreters/InDepthNodeVisitor.h:61: DB::DiskFromAST::createCustomDisk(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000164316ca 12. /build/src/Storages/MergeTree/MergeTreeSettings.cpp:398: DB::MergeTreeSettingsImpl::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x0000000016403b69 13. /build/src/Storages/MergeTree/MergeTreeSettings.cpp:714: DB::MergeTreeSettings::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x0000000016406404 14. /build/src/Storages/MergeTree/registerStorageMergeTree.cpp:705: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000165521de 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ca1a22 16. /build/src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001481ee32 17. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 18. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 19. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:16:14.950885 [ 27539 ] {ab28dc78-4587-424f-aa1a-b88be67ea647} 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]:34170) (comment: 01781_merge_tree_deduplication.sql) (query 37, line 83) (in query: DETACH TABLE merge_tree_deduplication;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Databases/DatabaseReplicated.cpp:1106: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013cc3688 5. /build/src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc384b 6. /build/src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833287 7. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 8. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 9. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:16:14.999773 [ 27539 ] {} TCPHandler: Code: 80. DB::Exception: DETACH TABLE is not allowed for Replicated databases. Use DETACH TABLE PERMANENTLY or SYSTEM RESTART REPLICA or set database_replicated_always_detach_permanently to 1. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Databases/DatabaseReplicated.cpp:1106: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013cc3688 5. /build/src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc384b 6. /build/src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833287 7. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 8. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 9. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:16:16.142824 [ 39959 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:16:16.857738 [ 16784 ] {083d73e8-5510-4d8c-8671-d3535fbb0b30} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 60021.01831 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:53008) (comment: 02455_one_row_from_csv_memory_usage.sh) (query 1, line 1) (in query: SELECT * FROM file('test_11_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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x0000000013ad84ab 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x0000000013ad77ec 5. /build/src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x000000001496af1f 6. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000168d1a5a 7. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0c24 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 2025.07.13 02:16:17.020915 [ 6612 ] {70bd245a-b3b2-49c0-97da-38b75a9555d9} executeQuery: Code: 691. DB::Exception: Unknown element '' for enum: In scope SELECT CAST(CAST('', 'Nullable(String)'), 'Nullable(Enum8(\'Hello\' = 1))'). (UNKNOWN_ELEMENT_OF_ENUM) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45636) (comment: 01402_cast_nullable_string_to_enum.sql) (query 4, line 7) (in query: -- empty string still not acceptable SELECT CAST(CAST('' AS Nullable(String)) AS Nullable(Enum8('Hello' = 1)));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000b1f7c4b 4. /build/src/DataTypes/EnumValues.cpp:72: DB::EnumValues<_BitInt(8)>::getValue(StringRef) const @ 0x0000000013b617b2 5. /build/src/Functions/FunctionsConversion.h:5613: 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 @ 0x0000000012e5fae6 6. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::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) @ 0x0000000012e5f8d2 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012e81e24 8. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000012e81ccc 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012cc745b 10. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fc534a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 14. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f75b 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:16:17.060144 [ 6612 ] {} TCPHandler: Code: 691. DB::Exception: Unknown element '' for enum: In scope SELECT CAST(CAST('', 'Nullable(String)'), 'Nullable(Enum8(\'Hello\' = 1))'). (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000b1f7c4b 4. /build/src/DataTypes/EnumValues.cpp:72: DB::EnumValues<_BitInt(8)>::getValue(StringRef) const @ 0x0000000013b617b2 5. /build/src/Functions/FunctionsConversion.h:5613: 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 @ 0x0000000012e5fae6 6. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::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) @ 0x0000000012e5f8d2 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012e81e24 8. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000012e81ccc 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012cc745b 10. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fc534a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 14. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f75b 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:16:17.112638 [ 30862 ] {ffb121eb-4ecd-49e5-a709-43b53d2736b0} executeQuery: Code: 47. DB::Exception: JOIN FULL OUTER JOIN ... USING (test_value) using identifier 'test_value' cannot be resolved from left table expression. In scope SELECT t1.value AS t1_value, toTypeName(t1_value), t2.value AS t2_value, toTypeName(t2_value) FROM test_table_join_1 AS t1 FULL OUTER JOIN test_table_join_2 AS t2 USING (test_value). (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34138) (comment: 02374_analyzer_join_using.gen.sql) (query 44, line 115) (in query: SELECT t1.value AS t1_value, toTypeName(t1_value), t2.value AS t2_value, toTypeName(t2_value) FROM test_table_join_1 AS t1 FULL JOIN test_table_join_2 AS t2 USING (test_value);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&, String&&) @ 0x0000000013f6a56b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5255: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f674f8 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 9. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 14. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 15. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 16. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 17. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 22. ? @ 0x00007f7210eb6ac3 23. ? @ 0x00007f7210f48850 2025.07.13 02:16:17.135767 [ 30862 ] {} TCPHandler: Code: 47. DB::Exception: JOIN FULL OUTER JOIN ... USING (test_value) using identifier 'test_value' cannot be resolved from left table expression. In scope SELECT t1.value AS t1_value, toTypeName(t1_value), t2.value AS t2_value, toTypeName(t2_value) FROM test_table_join_1 AS t1 FULL OUTER JOIN test_table_join_2 AS t2 USING (test_value). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&, String&&) @ 0x0000000013f6a56b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5255: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f674f8 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 9. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 14. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 15. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 16. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 17. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 22. ? @ 0x00007f7210eb6ac3 23. ? @ 0x00007f7210f48850 2025.07.13 02:16:17.483331 [ 6612 ] {eaa7bfab-1657-4961-9153-28c07c6d703b} executeQuery: Code: 691. DB::Exception: Unknown element '' for enum: In scope SELECT CAST(CAST('', 'Nullable(FixedString(1))'), 'Nullable(Enum8(\'Hello\' = 1))'). (UNKNOWN_ELEMENT_OF_ENUM) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45636) (comment: 01402_cast_nullable_string_to_enum.sql) (query 5, line 9) (in query: SELECT CAST(CAST('' AS Nullable(FixedString(1))) AS Nullable(Enum8('Hello' = 1)));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000b1f7c4b 4. /build/src/DataTypes/EnumValues.cpp:72: DB::EnumValues<_BitInt(8)>::getValue(StringRef) const @ 0x0000000013b617b2 5. /build/src/Functions/FunctionsConversion.h:5613: 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 @ 0x0000000012e60176 6. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::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) @ 0x0000000012e5ff12 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012e81e24 8. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000012e81ccc 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012cc745b 10. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fc534a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 14. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f75b 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:16:17.527487 [ 6612 ] {} TCPHandler: Code: 691. DB::Exception: Unknown element '' for enum: In scope SELECT CAST(CAST('', 'Nullable(FixedString(1))'), 'Nullable(Enum8(\'Hello\' = 1))'). (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000b1f7c4b 4. /build/src/DataTypes/EnumValues.cpp:72: DB::EnumValues<_BitInt(8)>::getValue(StringRef) const @ 0x0000000013b617b2 5. /build/src/Functions/FunctionsConversion.h:5613: 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 @ 0x0000000012e60176 6. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::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) @ 0x0000000012e5ff12 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012e81e24 8. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000012e81ccc 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012cc745b 10. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fc534a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 14. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f75b 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:16:17.584678 [ 16784 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 60021.01831 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x0000000013ad84ab 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x0000000013ad77ec 5. /build/src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x000000001496af1f 6. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000168d1a5a 7. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0c24 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:16:17.674311 [ 4922 ] {490a3476-79d1-4ff1-ab95-50c6da973121} executeQuery: Code: 497. DB::Exception: user_03327_permissions_on_refresh_mv_test_1_1: Not enough privileges. To execute this query, it's necessary to have the grant SYSTEM VIEWS ON test_1.mv_test_03327. (ACCESS_DENIED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45652) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000136a8744 5. /build/src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x00000000136a7203 6. /build/src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x00000000136a6851 7. /build/src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x0000000013679004 8. /build/src/Access/ContextAccess.h:256: void DB::Context::checkAccessImpl(DB::AccessFlags const&, String const&, String const&) const @ 0x0000000014374498 9. /build/src/Interpreters/Context.cpp:1759: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&) const @ 0x000000001434c97d 10. /build/src/Interpreters/InterpreterSystemQuery.cpp:1403: DB::InterpreterSystemQuery::getRefreshTasks() @ 0x0000000014bdada9 11. /build/src/Interpreters/InterpreterSystemQuery.cpp:741: DB::InterpreterSystemQuery::execute() @ 0x0000000014bd4246 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 14. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 15. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 20. ? @ 0x00007f7210eb6ac3 21. ? @ 0x00007f7210f48850 2025.07.13 02:16:17.711254 [ 4922 ] {} TCPHandler: Code: 497. DB::Exception: user_03327_permissions_on_refresh_mv_test_1_1: Not enough privileges. To execute this query, it's necessary to have the grant SYSTEM VIEWS ON test_1.mv_test_03327. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000136a8744 5. /build/src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x00000000136a7203 6. /build/src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x00000000136a6851 7. /build/src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x0000000013679004 8. /build/src/Access/ContextAccess.h:256: void DB::Context::checkAccessImpl(DB::AccessFlags const&, String const&, String const&) const @ 0x0000000014374498 9. /build/src/Interpreters/Context.cpp:1759: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&) const @ 0x000000001434c97d 10. /build/src/Interpreters/InterpreterSystemQuery.cpp:1403: DB::InterpreterSystemQuery::getRefreshTasks() @ 0x0000000014bdada9 11. /build/src/Interpreters/InterpreterSystemQuery.cpp:741: DB::InterpreterSystemQuery::execute() @ 0x0000000014bd4246 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 14. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 15. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 20. ? @ 0x00007f7210eb6ac3 21. ? @ 0x00007f7210f48850 2025.07.13 02:16:18.003270 [ 4922 ] {77053138-a396-44b5-8853-553cfa3f563e} executeQuery: Code: 497. DB::Exception: user_03327_permissions_on_refresh_mv_test_1_1: Not enough privileges. To execute this query, it's necessary to have the grant SYSTEM VIEWS ON test_1.mv_test_03327. (ACCESS_DENIED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45652) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000136a8744 5. /build/src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x00000000136a7203 6. /build/src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x00000000136a6851 7. /build/src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x0000000013679004 8. /build/src/Access/ContextAccess.h:256: DB::InterpreterSystemQuery::startStopAction(unsigned long, bool) @ 0x0000000014bd2550 9. /build/src/Interpreters/InterpreterSystemQuery.cpp:0: DB::InterpreterSystemQuery::execute() @ 0x0000000014bd5fe6 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:16:18.015910 [ 4922 ] {} TCPHandler: Code: 497. DB::Exception: user_03327_permissions_on_refresh_mv_test_1_1: Not enough privileges. To execute this query, it's necessary to have the grant SYSTEM VIEWS ON test_1.mv_test_03327. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000136a8744 5. /build/src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x00000000136a7203 6. /build/src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x00000000136a6851 7. /build/src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x0000000013679004 8. /build/src/Access/ContextAccess.h:256: DB::InterpreterSystemQuery::startStopAction(unsigned long, bool) @ 0x0000000014bd2550 9. /build/src/Interpreters/InterpreterSystemQuery.cpp:0: DB::InterpreterSystemQuery::execute() @ 0x0000000014bd5fe6 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:16:18.025974 [ 6612 ] {eca47edf-d843-4abd-8e40-2988ea956940} executeQuery: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: In scope SELECT CAST(CAST(NULL, 'Nullable(String)'), 'Enum8(\'Hello\' = 1)'). (CANNOT_INSERT_NULL_IN_ORDINARY_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45636) (comment: 01402_cast_nullable_string_to_enum.sql) (query 6, line 11) (in query: -- non-Nullable Enum() still not acceptable SELECT CAST(CAST(NULL AS Nullable(String)) AS Enum8('Hello' = 1));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/FunctionsConversion.h:5877: DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda0'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x0000000012e825c8 5. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool) const::'lambda0'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000012e823cc 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012cc745b 7. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fc534a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f75b 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:16:18.125490 [ 6612 ] {} TCPHandler: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: In scope SELECT CAST(CAST(NULL, 'Nullable(String)'), 'Enum8(\'Hello\' = 1)'). (CANNOT_INSERT_NULL_IN_ORDINARY_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/FunctionsConversion.h:5877: DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda0'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x0000000012e825c8 5. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool) const::'lambda0'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000012e823cc 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012cc745b 7. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fc534a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f75b 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:16:18.260708 [ 6612 ] {b2561eb6-bcd7-4a2a-bc84-1cfc729d62e7} executeQuery: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: In scope SELECT CAST(CAST(NULL, 'Nullable(FixedString(1))'), 'Enum8(\'Hello\' = 1)'). (CANNOT_INSERT_NULL_IN_ORDINARY_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45636) (comment: 01402_cast_nullable_string_to_enum.sql) (query 7, line 13) (in query: SELECT CAST(CAST(NULL AS Nullable(FixedString(1))) AS Enum8('Hello' = 1));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/FunctionsConversion.h:5877: DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda0'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x0000000012e825c8 5. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool) const::'lambda0'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000012e823cc 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012cc745b 7. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fc534a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f75b 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:16:18.288418 [ 6612 ] {} TCPHandler: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: In scope SELECT CAST(CAST(NULL, 'Nullable(FixedString(1))'), 'Enum8(\'Hello\' = 1)'). (CANNOT_INSERT_NULL_IN_ORDINARY_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/FunctionsConversion.h:5877: DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda0'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x0000000012e825c8 5. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool) const::'lambda0'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000012e823cc 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012cc745b 7. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fc534a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f75b 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:16:18.731288 [ 4922 ] {25d79ef2-1f0f-4b7f-b662-677791039e24} executeQuery: Code: 497. DB::Exception: user_03327_permissions_on_refresh_mv_test_1_1: Not enough privileges. To execute this query, it's necessary to have the grant SYSTEM VIEWS ON test_1.mv_test_03327. (ACCESS_DENIED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45652) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000136a8744 5. /build/src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x00000000136a7203 6. /build/src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x00000000136a6851 7. /build/src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x0000000013679004 8. /build/src/Access/ContextAccess.h:256: void DB::Context::checkAccessImpl(DB::AccessFlags const&, String const&, String const&) const @ 0x0000000014374498 9. /build/src/Interpreters/Context.cpp:1759: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&) const @ 0x000000001434c97d 10. /build/src/Interpreters/InterpreterSystemQuery.cpp:1403: DB::InterpreterSystemQuery::getRefreshTasks() @ 0x0000000014bdada9 11. /build/src/Interpreters/InterpreterSystemQuery.cpp:745: DB::InterpreterSystemQuery::execute() @ 0x0000000014bd5318 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 14. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 15. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 20. ? @ 0x00007f7210eb6ac3 21. ? @ 0x00007f7210f48850 2025.07.13 02:16:18.743247 [ 4922 ] {} TCPHandler: Code: 497. DB::Exception: user_03327_permissions_on_refresh_mv_test_1_1: Not enough privileges. To execute this query, it's necessary to have the grant SYSTEM VIEWS ON test_1.mv_test_03327. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000136a8744 5. /build/src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x00000000136a7203 6. /build/src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x00000000136a6851 7. /build/src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x0000000013679004 8. /build/src/Access/ContextAccess.h:256: void DB::Context::checkAccessImpl(DB::AccessFlags const&, String const&, String const&) const @ 0x0000000014374498 9. /build/src/Interpreters/Context.cpp:1759: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&) const @ 0x000000001434c97d 10. /build/src/Interpreters/InterpreterSystemQuery.cpp:1403: DB::InterpreterSystemQuery::getRefreshTasks() @ 0x0000000014bdada9 11. /build/src/Interpreters/InterpreterSystemQuery.cpp:745: DB::InterpreterSystemQuery::execute() @ 0x0000000014bd5318 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 14. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 15. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 20. ? @ 0x00007f7210eb6ac3 21. ? @ 0x00007f7210f48850 2025.07.13 02:16:18.984750 [ 4922 ] {ffa72284-e761-4a25-9809-e5b5b2087244} executeQuery: Code: 497. DB::Exception: user_03327_permissions_on_refresh_mv_test_1_1: Not enough privileges. To execute this query, it's necessary to have the grant SYSTEM VIEWS ON test_1.mv_test_03327. (ACCESS_DENIED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45652) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000136a8744 5. /build/src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x00000000136a7203 6. /build/src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x00000000136a6851 7. /build/src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x0000000013679004 8. /build/src/Access/ContextAccess.h:256: DB::InterpreterSystemQuery::startStopAction(unsigned long, bool) @ 0x0000000014bd2550 9. /build/src/Interpreters/InterpreterSystemQuery.cpp:0: DB::InterpreterSystemQuery::execute() @ 0x0000000014bd5fe6 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:16:18.993100 [ 4922 ] {} TCPHandler: Code: 497. DB::Exception: user_03327_permissions_on_refresh_mv_test_1_1: Not enough privileges. To execute this query, it's necessary to have the grant SYSTEM VIEWS ON test_1.mv_test_03327. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000136a8744 5. /build/src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x00000000136a7203 6. /build/src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x00000000136a6851 7. /build/src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x0000000013679004 8. /build/src/Access/ContextAccess.h:256: DB::InterpreterSystemQuery::startStopAction(unsigned long, bool) @ 0x0000000014bd2550 9. /build/src/Interpreters/InterpreterSystemQuery.cpp:0: DB::InterpreterSystemQuery::execute() @ 0x0000000014bd5fe6 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:16:19.128132 [ 4922 ] {099ea22f-ae5a-4b13-a236-18f1cd65e421} executeQuery: Code: 497. DB::Exception: user_03327_permissions_on_refresh_mv_test_1_1: Not enough privileges. To execute this query, it's necessary to have the grant SYSTEM VIEWS ON test_1.mv_test_03327. (ACCESS_DENIED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45652) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000136a8744 5. /build/src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x00000000136a7203 6. /build/src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x00000000136a6851 7. /build/src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x0000000013679004 8. /build/src/Access/ContextAccess.h:256: void DB::Context::checkAccessImpl(DB::AccessFlags const&, String const&, String const&) const @ 0x0000000014374498 9. /build/src/Interpreters/Context.cpp:1759: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&) const @ 0x000000001434c97d 10. /build/src/Interpreters/InterpreterSystemQuery.cpp:1403: DB::InterpreterSystemQuery::getRefreshTasks() @ 0x0000000014bdada9 11. /build/src/Interpreters/InterpreterSystemQuery.cpp:749: DB::InterpreterSystemQuery::execute() @ 0x0000000014bd3e66 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 14. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 15. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 20. ? @ 0x00007f7210eb6ac3 21. ? @ 0x00007f7210f48850 2025.07.13 02:16:19.145680 [ 4922 ] {} TCPHandler: Code: 497. DB::Exception: user_03327_permissions_on_refresh_mv_test_1_1: Not enough privileges. To execute this query, it's necessary to have the grant SYSTEM VIEWS ON test_1.mv_test_03327. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000136a8744 5. /build/src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x00000000136a7203 6. /build/src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x00000000136a6851 7. /build/src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x0000000013679004 8. /build/src/Access/ContextAccess.h:256: void DB::Context::checkAccessImpl(DB::AccessFlags const&, String const&, String const&) const @ 0x0000000014374498 9. /build/src/Interpreters/Context.cpp:1759: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&) const @ 0x000000001434c97d 10. /build/src/Interpreters/InterpreterSystemQuery.cpp:1403: DB::InterpreterSystemQuery::getRefreshTasks() @ 0x0000000014bdada9 11. /build/src/Interpreters/InterpreterSystemQuery.cpp:749: DB::InterpreterSystemQuery::execute() @ 0x0000000014bd3e66 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 14. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 15. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 20. ? @ 0x00007f7210eb6ac3 21. ? @ 0x00007f7210f48850 2025.07.13 02:16:19.841062 [ 31799 ] {29bcbf16-2b19-438f-b512-b48f4c61eab6} executeQuery: Code: 57. DB::Exception: Table test_15.quorum2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45950) (comment: 02377_majority_insert_quorum_zookeeper_long.sql) (query 18, line 34) (in query: CREATE TABLE quorum2 (`x` UInt32, `y` Date) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/test_02377/quorum1', '2') PARTITION BY y ORDER BY x SETTINGS index_granularity = 22505, min_bytes_for_wide_part = 316154073, ratio_of_defaults_for_sparse_serialization = 0.3077141046524048, replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 76519063, compact_parts_max_bytes_to_buffer = 336169662, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 29828563, merge_max_block_size = 15116, old_parts_lifetime = 268., prefer_fetch_merged_part_size_threshold = 10551947713, 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 = 26758009, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 45, 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 = 86172, primary_key_compress_block_size = 94132, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:16:19.851906 [ 31799 ] {} TCPHandler: Code: 57. DB::Exception: Table test_15.quorum2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:16:21.203469 [ 12991 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:16:22.112992 [ 3543 ] {d6db6f92-e33b-4773-adf6-8ef440daef04} executeQuery: Code: 6. DB::Exception: Cannot parse string '2022-08-22+01:02:03' as Date: syntax error at position 10 (parsed just '2022-08-22'): In scope SELECT toDate('2022-08-22+01:02:03'). (CANNOT_PARSE_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45718) (comment: 02388_conversion_from_string_with_datetime64_to_date_and_date32.sql) (query 13, line 20) (in query: SELECT toDate('2022-08-22+01:02:03');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000012f57580 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000012f5713e 6. /build/src/Functions/FunctionsConversion.h:2472: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e92570 7. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eab4ce 8. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eaacfa 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:16:22.136657 [ 3543 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2022-08-22+01:02:03' as Date: syntax error at position 10 (parsed just '2022-08-22'): In scope SELECT toDate('2022-08-22+01:02:03'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000012f57580 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000012f5713e 6. /build/src/Functions/FunctionsConversion.h:2472: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e92570 7. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eab4ce 8. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eaacfa 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:16:22.430747 [ 3543 ] {36fa7f69-162a-4eb1-9467-0af52571cb52} executeQuery: Code: 6. DB::Exception: Cannot parse string '2022-08-22+01:02:03' as Date32: syntax error at position 10 (parsed just '2022-08-22'): In scope SELECT toDate32('2022-08-22+01:02:03'). (CANNOT_PARSE_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45718) (comment: 02388_conversion_from_string_with_datetime64_to_date_and_date32.sql) (query 14, line 21) (in query: SELECT toDate32('2022-08-22+01:02:03');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000012f66cdd 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000012f668be 6. /build/src/Functions/FunctionsConversion.h:2472: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e92cd0 7. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eac8ae 8. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eac0da 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:16:22.454567 [ 3543 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2022-08-22+01:02:03' as Date32: syntax error at position 10 (parsed just '2022-08-22'): In scope SELECT toDate32('2022-08-22+01:02:03'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000012f66cdd 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000012f668be 6. /build/src/Functions/FunctionsConversion.h:2472: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e92cd0 7. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eac8ae 8. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eac0da 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:16:22.565995 [ 3543 ] {f5d83e08-a265-483c-b5d4-2eb428baaed5} executeQuery: Code: 6. DB::Exception: Cannot parse string '2022-08-22 01:02:0' as Date: syntax error at position 10 (parsed just '2022-08-22'): In scope SELECT toDate('2022-08-22 01:02:0'). (CANNOT_PARSE_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45718) (comment: 02388_conversion_from_string_with_datetime64_to_date_and_date32.sql) (query 15, line 23) (in query: SELECT toDate('2022-08-22 01:02:0');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000012f57580 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000012f5713e 6. /build/src/Functions/FunctionsConversion.h:2472: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e92570 7. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eab4ce 8. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eaacfa 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:16:22.591554 [ 3543 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2022-08-22 01:02:0' as Date: syntax error at position 10 (parsed just '2022-08-22'): In scope SELECT toDate('2022-08-22 01:02:0'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000012f57580 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000012f5713e 6. /build/src/Functions/FunctionsConversion.h:2472: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e92570 7. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eab4ce 8. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eaacfa 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:16:22.738277 [ 3543 ] {0bc0e4dc-d74a-4391-9029-bcbaec33ea1d} executeQuery: Code: 6. DB::Exception: Cannot parse string '2022-08-22 01:02:0' as Date32: syntax error at position 10 (parsed just '2022-08-22'): In scope SELECT toDate32('2022-08-22 01:02:0'). (CANNOT_PARSE_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45718) (comment: 02388_conversion_from_string_with_datetime64_to_date_and_date32.sql) (query 16, line 24) (in query: SELECT toDate32('2022-08-22 01:02:0');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000012f66cdd 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000012f668be 6. /build/src/Functions/FunctionsConversion.h:2472: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e92cd0 7. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eac8ae 8. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eac0da 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:16:22.750855 [ 3543 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2022-08-22 01:02:0' as Date32: syntax error at position 10 (parsed just '2022-08-22'): In scope SELECT toDate32('2022-08-22 01:02:0'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000012f66cdd 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000012f668be 6. /build/src/Functions/FunctionsConversion.h:2472: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e92cd0 7. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eac8ae 8. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eac0da 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:16:22.867737 [ 3543 ] {67257072-8ab9-4d7e-b70c-e831b2f9861b} executeQuery: Code: 6. DB::Exception: Cannot parse string '2022-08-22 01:02:03.' as Date: syntax error at position 10 (parsed just '2022-08-22'): In scope SELECT toDate('2022-08-22 01:02:03.'). (CANNOT_PARSE_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45718) (comment: 02388_conversion_from_string_with_datetime64_to_date_and_date32.sql) (query 17, line 26) (in query: SELECT toDate('2022-08-22 01:02:03.');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000012f57580 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000012f5713e 6. /build/src/Functions/FunctionsConversion.h:2472: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e92570 7. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eab4ce 8. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eaacfa 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:16:22.952007 [ 3543 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2022-08-22 01:02:03.' as Date: syntax error at position 10 (parsed just '2022-08-22'): In scope SELECT toDate('2022-08-22 01:02:03.'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000012f57580 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000012f5713e 6. /build/src/Functions/FunctionsConversion.h:2472: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e92570 7. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eab4ce 8. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eaacfa 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:16:23.074758 [ 3543 ] {8221e96c-ad4c-456b-9adc-726613da3bb6} executeQuery: Code: 6. DB::Exception: Cannot parse string '2022-08-22 01:02:03.' as Date32: syntax error at position 10 (parsed just '2022-08-22'): In scope SELECT toDate32('2022-08-22 01:02:03.'). (CANNOT_PARSE_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45718) (comment: 02388_conversion_from_string_with_datetime64_to_date_and_date32.sql) (query 18, line 27) (in query: SELECT toDate32('2022-08-22 01:02:03.');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000012f66cdd 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000012f668be 6. /build/src/Functions/FunctionsConversion.h:2472: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e92cd0 7. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eac8ae 8. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eac0da 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:16:23.114383 [ 3543 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2022-08-22 01:02:03.' as Date32: syntax error at position 10 (parsed just '2022-08-22'): In scope SELECT toDate32('2022-08-22 01:02:03.'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000012f66cdd 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000012f668be 6. /build/src/Functions/FunctionsConversion.h:2472: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e92cd0 7. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eac8ae 8. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eac0da 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:16:23.264315 [ 3543 ] {1da8536b-e57c-477d-8690-72a9dd8472fb} executeQuery: Code: 6. DB::Exception: Cannot parse string '2022-08-22 01:02:03.111a' as Date: syntax error at position 23 (parsed just '2022-08-22 01:02:03.111'): In scope SELECT toDate('2022-08-22 01:02:03.111a'). (CANNOT_PARSE_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45718) (comment: 02388_conversion_from_string_with_datetime64_to_date_and_date32.sql) (query 19, line 29) (in query: SELECT toDate('2022-08-22 01:02:03.111a');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000012f57580 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000012f5713e 6. /build/src/Functions/FunctionsConversion.h:2472: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e92570 7. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eab4ce 8. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eaacfa 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:16:23.292830 [ 3543 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2022-08-22 01:02:03.111a' as Date: syntax error at position 23 (parsed just '2022-08-22 01:02:03.111'): In scope SELECT toDate('2022-08-22 01:02:03.111a'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000012f57580 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000012f5713e 6. /build/src/Functions/FunctionsConversion.h:2472: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e92570 7. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eab4ce 8. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eaacfa 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:16:23.388294 [ 3543 ] {17bbd427-5cc4-4c9f-b828-7696dd2f8949} executeQuery: Code: 6. DB::Exception: Cannot parse string '2022-08-22 01:02:03.2b' as Date32: syntax error at position 21 (parsed just '2022-08-22 01:02:03.2'): In scope SELECT toDate32('2022-08-22 01:02:03.2b'). (CANNOT_PARSE_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45718) (comment: 02388_conversion_from_string_with_datetime64_to_date_and_date32.sql) (query 20, line 30) (in query: SELECT toDate32('2022-08-22 01:02:03.2b');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000012f66cdd 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000012f668be 6. /build/src/Functions/FunctionsConversion.h:2472: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e92cd0 7. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eac8ae 8. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eac0da 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:16:23.403399 [ 3543 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2022-08-22 01:02:03.2b' as Date32: syntax error at position 21 (parsed just '2022-08-22 01:02:03.2'): In scope SELECT toDate32('2022-08-22 01:02:03.2b'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000012f66cdd 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000012f668be 6. /build/src/Functions/FunctionsConversion.h:2472: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e92cd0 7. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eac8ae 8. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eac0da 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:16:23.493232 [ 3543 ] {037e9c00-de66-42d5-a703-30f2e7dfff17} executeQuery: Code: 6. DB::Exception: Cannot parse string '2022-08-22 01:02:03.a' as Date: syntax error at position 20 (parsed just '2022-08-22 01:02:03.'): In scope SELECT toDate('2022-08-22 01:02:03.a'). (CANNOT_PARSE_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45718) (comment: 02388_conversion_from_string_with_datetime64_to_date_and_date32.sql) (query 21, line 32) (in query: SELECT toDate('2022-08-22 01:02:03.a');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000012f57580 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000012f5713e 6. /build/src/Functions/FunctionsConversion.h:2472: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e92570 7. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eab4ce 8. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eaacfa 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:16:23.505853 [ 3543 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2022-08-22 01:02:03.a' as Date: syntax error at position 20 (parsed just '2022-08-22 01:02:03.'): In scope SELECT toDate('2022-08-22 01:02:03.a'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000012f57580 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000012f5713e 6. /build/src/Functions/FunctionsConversion.h:2472: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e92570 7. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eab4ce 8. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eaacfa 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:16:23.692049 [ 3543 ] {949447f8-b23f-49dd-806e-5450238e2fdf} executeQuery: Code: 6. DB::Exception: Cannot parse string '2022-08-22 01:02:03.b' as Date32: syntax error at position 20 (parsed just '2022-08-22 01:02:03.'): In scope SELECT toDate32('2022-08-22 01:02:03.b'). (CANNOT_PARSE_TEXT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45718) (comment: 02388_conversion_from_string_with_datetime64_to_date_and_date32.sql) (query 22, line 33) (in query: SELECT toDate32('2022-08-22 01:02:03.b');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000012f66cdd 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000012f668be 6. /build/src/Functions/FunctionsConversion.h:2472: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e92cd0 7. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eac8ae 8. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eac0da 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:16:23.726371 [ 3543 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2022-08-22 01:02:03.b' as Date32: syntax error at position 20 (parsed just '2022-08-22 01:02:03.'): In scope SELECT toDate32('2022-08-22 01:02:03.b'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a094d93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000012f66cdd 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000012f668be 6. /build/src/Functions/FunctionsConversion.h:2472: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012e92cd0 7. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eac8ae 8. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012eac0da 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 30. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 31. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 2025.07.13 02:16:24.327663 [ 30862 ] {d3573e3d-b268-4156-bc5d-b1026b7fa739} executeQuery: Code: 207. DB::Exception: JOIN INNER JOIN ... ON t1.id = t2.id ambiguous identifier 'id'. In scope SELECT id FROM test_table_join_1 AS t1 INNER JOIN test_table_join_2 AS t2 ON t1.id = t2.id INNER JOIN test_table_join_3 AS t3 USING (id). (AMBIGUOUS_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34138) (comment: 02374_analyzer_join_using.gen.sql) (query 51, line 137) (in query: SELECT id FROM test_table_join_1 AS t1 INNER JOIN test_table_join_2 AS t2 ON t1.id = t2.id INNER JOIN test_table_join_3 AS t3 USING (id);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000013f6a64b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1013: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141df0fc 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141ddd52 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5226: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f6638e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 16. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:16:24.389771 [ 30862 ] {} TCPHandler: Code: 207. DB::Exception: JOIN INNER JOIN ... ON t1.id = t2.id ambiguous identifier 'id'. In scope SELECT id FROM test_table_join_1 AS t1 INNER JOIN test_table_join_2 AS t2 ON t1.id = t2.id INNER JOIN test_table_join_3 AS t3 USING (id). (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000013f6a64b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1013: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141df0fc 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141ddd52 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5226: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f6638e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 16. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:16:25.031467 [ 4922 ] {3e8b5e9a-a194-4df6-9927-6b3f80a96bcc} 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]:52278) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/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&&) @ 0x000000001389430b 4. /build/src/Analyzer/ValidationUtils.cpp:50: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x0000000013f84ad0 5. /build/src/Analyzer/ValidationUtils.cpp:74: DB::validateFilters(std::shared_ptr const&) @ 0x0000000013f847b5 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5758: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f33291 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 9. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 14. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 15. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 16. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 17. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 22. ? @ 0x00007f7210eb6ac3 23. ? @ 0x00007f7210f48850 2025.07.13 02:16:25.043769 [ 4922 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/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&&) @ 0x000000001389430b 4. /build/src/Analyzer/ValidationUtils.cpp:50: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x0000000013f84ad0 5. /build/src/Analyzer/ValidationUtils.cpp:74: DB::validateFilters(std::shared_ptr const&) @ 0x0000000013f847b5 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5758: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f33291 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 9. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 14. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 15. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 16. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 17. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 22. ? @ 0x00007f7210eb6ac3 23. ? @ 0x00007f7210f48850 2025.07.13 02:16:25.325079 [ 4922 ] {e10b8795-1d7f-4f48-b82b-3f41f33de149} 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]:52278) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/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&&) @ 0x000000001389430b 4. /build/src/Analyzer/ValidationUtils.cpp:50: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x0000000013f84ad0 5. /build/src/Analyzer/ValidationUtils.cpp:74: DB::validateFilters(std::shared_ptr const&) @ 0x0000000013f847b5 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5758: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f33291 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 9. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 12. /build/src/Interpreters/InterpreterDescribeQuery.cpp:143: DB::InterpreterDescribeQuery::fillColumnsFromSubquery(DB::ASTTableExpression const&) @ 0x0000000014bfb605 13. /build/src/Interpreters/InterpreterDescribeQuery.cpp:100: DB::InterpreterDescribeQuery::execute() @ 0x0000000014bfaf01 14. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 15. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 16. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 17. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 22. ? @ 0x00007f7210eb6ac3 23. ? @ 0x00007f7210f48850 2025.07.13 02:16:25.333778 [ 4922 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/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&&) @ 0x000000001389430b 4. /build/src/Analyzer/ValidationUtils.cpp:50: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x0000000013f84ad0 5. /build/src/Analyzer/ValidationUtils.cpp:74: DB::validateFilters(std::shared_ptr const&) @ 0x0000000013f847b5 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5758: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f33291 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 9. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 12. /build/src/Interpreters/InterpreterDescribeQuery.cpp:143: DB::InterpreterDescribeQuery::fillColumnsFromSubquery(DB::ASTTableExpression const&) @ 0x0000000014bfb605 13. /build/src/Interpreters/InterpreterDescribeQuery.cpp:100: DB::InterpreterDescribeQuery::execute() @ 0x0000000014bfaf01 14. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 15. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 16. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 17. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 22. ? @ 0x00007f7210eb6ac3 23. ? @ 0x00007f7210f48850 2025.07.13 02:16:26.307464 [ 40061 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:16:27.026812 [ 4922 ] {6de5061d-f00a-4763-a839-8ba660091cd7} 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]:52324) (comment: 02789_object_type_invalid_num_of_rows.sql) (query 1, line 1) (in query: set allow_experimental_object_type=1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:16:27.051776 [ 4922 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:16:29.740949 [ 30862 ] {591a59f5-2f96-4651-be36-0273650de898} executeQuery: Code: 207. DB::Exception: JOIN INNER JOIN ... ON t1.id = t2.id ambiguous identifier 'id'. In scope SELECT id FROM test_table_join_1 AS t1 INNER JOIN test_table_join_2 AS t2 ON t1.id = t2.id LEFT JOIN test_table_join_3 AS t3 USING (id). (AMBIGUOUS_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34138) (comment: 02374_analyzer_join_using.gen.sql) (query 58, line 156) (in query: SELECT id FROM test_table_join_1 AS t1 INNER JOIN test_table_join_2 AS t2 ON t1.id = t2.id LEFT JOIN test_table_join_3 AS t3 USING (id);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000013f6a64b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1013: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141df0fc 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141ddd52 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5226: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f6638e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 16. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:16:29.748415 [ 30862 ] {} TCPHandler: Code: 207. DB::Exception: JOIN INNER JOIN ... ON t1.id = t2.id ambiguous identifier 'id'. In scope SELECT id FROM test_table_join_1 AS t1 INNER JOIN test_table_join_2 AS t2 ON t1.id = t2.id LEFT JOIN test_table_join_3 AS t3 USING (id). (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000013f6a64b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1013: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141df0fc 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141ddd52 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5226: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f6638e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 16. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:16:30.390016 [ 4930 ] {7067ea16-2eb3-4453-8955-756d718fa4fc} executeQuery: Code: 182. DB::Exception: Table expression merge(currentDatabase(), '^abc$') does not support column __table1._table in PREWHERE. In query SELECT f2 FROM merge(currentDatabase(), '^abc$') PREWHERE (_table = 'abc') AND (f1 = 'a') AND ((rand() % 100) < 20). (ILLEGAL_PREWHERE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44348) (comment: 01915_merge_prewhere_virtual_column_rand_chao_wang.sql) (query 3, line 11) (in query: -- In version 20.12 this query sometimes produces an exception "Cannot find column" SELECT f2 FROM merge(currentDatabase(), '^abc$') PREWHERE _table = 'abc' AND f1 = 'a' AND rand() % 100 < 20;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000141ee6ed 5. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000141ee3ea 6. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000141ee3ea 7. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000141ee3ea 8. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000141ee3ea 9. /build/src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000141ec35f 10. /build/src/Planner/Planner.cpp:1501: DB::Planner::buildPlanForQueryNode() @ 0x000000001489778c 11. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 13. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:16:30.405758 [ 4930 ] {} TCPHandler: Code: 182. DB::Exception: Table expression merge(currentDatabase(), '^abc$') does not support column __table1._table in PREWHERE. In query SELECT f2 FROM merge(currentDatabase(), '^abc$') PREWHERE (_table = 'abc') AND (f1 = 'a') AND ((rand() % 100) < 20). (ILLEGAL_PREWHERE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000141ee6ed 5. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000141ee3ea 6. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000141ee3ea 7. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000141ee3ea 8. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000141ee3ea 9. /build/src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000141ec35f 10. /build/src/Planner/Planner.cpp:1501: DB::Planner::buildPlanForQueryNode() @ 0x000000001489778c 11. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 13. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:16:30.535225 [ 5998 ] {5bf1023a-6871-4b0b-9e9b-382d1e277920} 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]:52292) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000013f69e39 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f3a889 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:16:30.547218 [ 5998 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000013f69e39 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f3a889 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:16:30.629993 [ 5998 ] {f91ba888-cf9d-4bb0-9702-bcdc91461d9e} 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]:52292) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000013f69e39 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f3a889 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:16:30.655741 [ 5998 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000013f69e39 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f3a889 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:16:30.686999 [ 4930 ] {540c615d-ee11-42d1-b31b-02f6e9b3cd3d} executeQuery: Code: 182. DB::Exception: Table expression merge(currentDatabase(), '^abc$') does not support column __table1._table in PREWHERE. In query SELECT f2 FROM merge(currentDatabase(), '^abc$') PREWHERE (_table = 'abc') AND (f1 = 'a'). (ILLEGAL_PREWHERE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44348) (comment: 01915_merge_prewhere_virtual_column_rand_chao_wang.sql) (query 4, line 13) (in query: SELECT f2 FROM merge(currentDatabase(), '^abc$') PREWHERE _table = 'abc' AND f1 = 'a';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000141ee6ed 5. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000141ee3ea 6. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000141ee3ea 7. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000141ee3ea 8. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000141ee3ea 9. /build/src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000141ec35f 10. /build/src/Planner/Planner.cpp:1501: DB::Planner::buildPlanForQueryNode() @ 0x000000001489778c 11. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 13. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:16:30.709108 [ 4930 ] {} TCPHandler: Code: 182. DB::Exception: Table expression merge(currentDatabase(), '^abc$') does not support column __table1._table in PREWHERE. In query SELECT f2 FROM merge(currentDatabase(), '^abc$') PREWHERE (_table = 'abc') AND (f1 = 'a'). (ILLEGAL_PREWHERE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000141ee6ed 5. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000141ee3ea 6. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000141ee3ea 7. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000141ee3ea 8. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000141ee3ea 9. /build/src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000141ec35f 10. /build/src/Planner/Planner.cpp:1501: DB::Planner::buildPlanForQueryNode() @ 0x000000001489778c 11. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 13. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:16:31.256271 [ 16763 ] {df37705d-887c-4719-8732-f3fb2546338a} executeQuery: Code: 407. DB::Exception: Intermediate result overflow (signed a = -256, signed b = 9223372036854775807, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT ignore(lcm(-256, 9223372036854775807)). (DECIMAL_OVERFLOW) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44338) (comment: 01435_lcm_overflow.sql) (query 7, line 9) (in query: SELECT ignore(lcm(-256, 9223372036854775807));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x000000000b9548ab 4. /build/src/Functions/GCDLCMImpl.h:44: long DB::GCDLCMImpl, DB::(anonymous namespace)::NameLCM>::apply(short, unsigned long) @ 0x000000000c73a47f 5. /build/src/Functions/FunctionBinaryArithmetic.h:309: _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS_15DataTypeDecimalINS_7DecimalIiEEEENSL_INSM_IlEEEENSL_INSM_ISH_EEEENSL_INSM_ISJ_EEEENS_12DataTypeDateENS_16DataTypeDateTimeENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZZNS_24FunctionBinaryArithmeticINS_12_GLOBAL__N_17LCMImplENS12_7NameLCMELb0ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clISE_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000000c786a69 6. /build/src/Functions/FunctionBinaryArithmetic.h:838: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000c7575b5 7. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c755cf7 8. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c754c94 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 31. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 2025.07.13 02:16:31.256942 [ 39957 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:16:31.274521 [ 16763 ] {} TCPHandler: Code: 407. DB::Exception: Intermediate result overflow (signed a = -256, signed b = 9223372036854775807, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT ignore(lcm(-256, 9223372036854775807)). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x000000000b9548ab 4. /build/src/Functions/GCDLCMImpl.h:44: long DB::GCDLCMImpl, DB::(anonymous namespace)::NameLCM>::apply(short, unsigned long) @ 0x000000000c73a47f 5. /build/src/Functions/FunctionBinaryArithmetic.h:309: _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS_15DataTypeDecimalINS_7DecimalIiEEEENSL_INSM_IlEEEENSL_INSM_ISH_EEEENSL_INSM_ISJ_EEEENS_12DataTypeDateENS_16DataTypeDateTimeENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZZNS_24FunctionBinaryArithmeticINS_12_GLOBAL__N_17LCMImplENS12_7NameLCMELb0ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clISE_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000000c786a69 6. /build/src/Functions/FunctionBinaryArithmetic.h:838: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000c7575b5 7. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c755cf7 8. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c754c94 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 31. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 2025.07.13 02:16:32.018077 [ 4888 ] {8dbcab67-1fc8-41fc-bd21-831f7dac7509} 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]:44386) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/TableFunctions/TableFunctionNumbers.cpp:105: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x000000001170ca4b 5. /build/src/TableFunctions/TableFunctionNumbers.cpp:80: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000001170bc45 6. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000130d4903 7. /build/src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000143537f2 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3da49 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:16:32.029564 [ 4888 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/TableFunctions/TableFunctionNumbers.cpp:105: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x000000001170ca4b 5. /build/src/TableFunctions/TableFunctionNumbers.cpp:80: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000001170bc45 6. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000130d4903 7. /build/src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000143537f2 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3da49 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:16:32.196353 [ 4888 ] {1eead616-4392-43ec-9c1f-955a78642fc9} 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]:44386) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/TableFunctions/TableFunctionNumbers.cpp:109: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x000000001170caea 5. /build/src/TableFunctions/TableFunctionNumbers.cpp:80: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000001170bc45 6. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000130d4903 7. /build/src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000143537f2 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3da49 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:16:32.217825 [ 4888 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/TableFunctions/TableFunctionNumbers.cpp:109: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x000000001170caea 5. /build/src/TableFunctions/TableFunctionNumbers.cpp:80: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000001170bc45 6. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000130d4903 7. /build/src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000143537f2 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3da49 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:16:32.301136 [ 4888 ] {ca855b3e-d1ae-4b61-b51b-b008f63faf08} 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]:44386) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/TableFunctions/TableFunctionNumbers.cpp:109: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x000000001170caea 5. /build/src/TableFunctions/TableFunctionNumbers.cpp:80: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000001170bc45 6. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000130d4903 7. /build/src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000143537f2 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3da49 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:16:32.320241 [ 4888 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/TableFunctions/TableFunctionNumbers.cpp:109: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x000000001170caea 5. /build/src/TableFunctions/TableFunctionNumbers.cpp:80: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000001170bc45 6. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000130d4903 7. /build/src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000143537f2 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3da49 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:16:32.633121 [ 4887 ] {49ffcf33-0014-4d38-9359-50c8ef9240ea} 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 [::ffff:127.0.0.1]:47426) (comment: 00971_merge_tree_uniform_read_distribution_and_max_rows_to_read.sql) (query 9, line 13) (in query: SELECT count() AS `count()` FROM `test_15`.`merge_tree` AS `__table1` WHERE NOT ignore(`__table1`.`x`)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000013af9d2b 4. /build/src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013af96d2 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x0000000016d41675 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d56e9c 7. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016cf6870 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:16:32.632780 [ 5015 ] {be36f961-cb1a-4832-ad28-140e9b290407} 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 [::ffff:127.0.0.1]:59162) (comment: 00971_merge_tree_uniform_read_distribution_and_max_rows_to_read.sql) (query 9, line 13) (in query: SELECT count() AS `count()` FROM `test_15`.`merge_tree` AS `__table1` WHERE NOT ignore(`__table1`.`x`)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000013af9d2b 4. /build/src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013af96d2 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x0000000016d41675 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d56e9c 7. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016cf6870 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:16:32.653924 [ 4887 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000013af9d2b 4. /build/src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013af96d2 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x0000000016d41675 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d56e9c 7. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016cf6870 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:16:32.655832 [ 5015 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000013af9d2b 4. /build/src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013af96d2 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x0000000016d41675 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d56e9c 7. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016cf6870 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:16:32.763783 [ 37317 ] {bee50313-63bd-4607-acea-5e890f6fafed} executeQuery: Code: 158. DB::Exception: Received from 127.0.0.10:9000. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 900.00 thousand, current rows: 1.00 million. Stack trace: 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000013af9d2b 4. /build/src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013af96d2 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x0000000016d41675 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d56e9c 7. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016cf6870 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 : While executing Remote. (TOO_MANY_ROWS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44360) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fb80677 3. /build/src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x00000000166f5247 4. /build/src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000166fc432 5. /build/src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x0000000016737609 6. /build/src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000013af731e 7. /build/src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013af6952 8. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013af679a 9. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013af64e1 2025.07.13 02:16:32.783823 [ 37317 ] {} TCPHandler: Code: 158. DB::Exception: Received from 127.0.0.10:9000. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 900.00 thousand, current rows: 1.00 million. Stack trace: 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000013af9d2b 4. /build/src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013af96d2 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x0000000016d41675 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d56e9c 7. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016cf6870 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 : While executing Remote. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fb80677 3. /build/src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x00000000166f5247 4. /build/src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000166fc432 5. /build/src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x0000000016737609 6. /build/src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000013af731e 7. /build/src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013af6952 8. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013af679a 9. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013af64e1 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:16:33.587815 [ 16757 ] {c15fd529-d018-4891-8be6-31b721221923} 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 [::ffff:127.0.0.1]:59634) (comment: 00971_merge_tree_uniform_read_distribution_and_max_rows_to_read.sql) (query 10, line 15) (in query: SELECT count() AS `count()` FROM `test_15`.`merge_tree` AS `__table1` WHERE NOT ignore(`__table1`.`x`)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000013af9d2b 4. /build/src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013af96d2 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x0000000016d41675 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d56e9c 7. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016cf6870 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:16:33.607349 [ 16757 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000013af9d2b 4. /build/src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013af96d2 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x0000000016d41675 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d56e9c 7. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016cf6870 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:16:33.653230 [ 4879 ] {3011269a-85fe-4976-82b1-3fbe07b67d0a} 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 [::ffff:127.0.0.1]:36540) (comment: 00971_merge_tree_uniform_read_distribution_and_max_rows_to_read.sql) (query 10, line 15) (in query: SELECT count() AS `count()` FROM `test_15`.`merge_tree` AS `__table1` WHERE NOT ignore(`__table1`.`x`)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000013af9d2b 4. /build/src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013af96d2 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x0000000016d41675 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d56e9c 7. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016cf6870 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:16:33.704387 [ 4879 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000013af9d2b 4. /build/src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013af96d2 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x0000000016d41675 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d56e9c 7. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016cf6870 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:16:33.732540 [ 4922 ] {9a4f7960-1976-4bf2-95e6-35821a099748} 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 [::ffff:127.0.0.1]:43618) (comment: 00971_merge_tree_uniform_read_distribution_and_max_rows_to_read.sql) (query 10, line 15) (in query: SELECT count() AS `count()` FROM `test_15`.`merge_tree` AS `__table1` WHERE NOT ignore(`__table1`.`x`)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000013af9d2b 4. /build/src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013af96d2 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x0000000016d41675 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d56e9c 7. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016cf6870 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:16:33.763328 [ 4922 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000013af9d2b 4. /build/src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013af96d2 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x0000000016d41675 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d56e9c 7. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016cf6870 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:16:33.787974 [ 37317 ] {16796ad9-a1a0-4be5-95cc-214024fbeb43} 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: 900.00 thousand, current rows: 1.00 million. Stack trace: 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000013af9d2b 4. /build/src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013af96d2 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x0000000016d41675 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d56e9c 7. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016cf6870 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 : While executing Remote. (TOO_MANY_ROWS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44360) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fb80677 3. /build/src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x00000000166f5247 4. /build/src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000166fc432 5. /build/src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x0000000016737609 6. /build/src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000013af731e 7. /build/src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013af6952 8. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013af679a 9. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013af64e1 2025.07.13 02:16:33.849358 [ 37317 ] {} 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: 900.00 thousand, current rows: 1.00 million. Stack trace: 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000013af9d2b 4. /build/src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013af96d2 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x0000000016d41675 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d56e9c 7. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016cf6870 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 : While executing Remote. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fb80677 3. /build/src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x00000000166f5247 4. /build/src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000166fc432 5. /build/src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x0000000016737609 6. /build/src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000013af731e 7. /build/src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013af6952 8. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013af679a 9. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013af64e1 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:16:35.141959 [ 37313 ] {1cc21414-626a-4511-aba4-2dd10c5e66a5} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=873, jobs=837). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58338) (comment: 02366_kql_func_ip.sql) (query 87, line 94) (in query: print format_ipv4_mask('abc', 24) == '';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbdd1d3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd751c 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 9. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 10. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:16:35.169634 [ 37313 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=873, jobs=837). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbdd1d3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd751c 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 9. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 10. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:16:35.934856 [ 5998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778c58 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168167bf 10. /build/src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000001680ff45 11. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:16:35.945052 [ 5998 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x0000000016810069 5. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 6. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 2025.07.13 02:16:36.404580 [ 5991 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:16:36.756411 [ 30862 ] {20802196-cf96-484c-be0f-0f5cddb62ac0} executeQuery: Code: 207. DB::Exception: JOIN INNER JOIN ... ON t1.id = t2.id ambiguous identifier 'id'. In scope SELECT id FROM test_table_join_1 AS t1 INNER JOIN test_table_join_2 AS t2 ON t1.id = t2.id RIGHT JOIN test_table_join_3 AS t3 USING (id). (AMBIGUOUS_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34138) (comment: 02374_analyzer_join_using.gen.sql) (query 65, line 175) (in query: SELECT id FROM test_table_join_1 AS t1 INNER JOIN test_table_join_2 AS t2 ON t1.id = t2.id RIGHT JOIN test_table_join_3 AS t3 USING (id);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000013f6a64b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1013: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141df0fc 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141ddd52 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5226: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f6638e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 16. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:16:36.793617 [ 30862 ] {} TCPHandler: Code: 207. DB::Exception: JOIN INNER JOIN ... ON t1.id = t2.id ambiguous identifier 'id'. In scope SELECT id FROM test_table_join_1 AS t1 INNER JOIN test_table_join_2 AS t2 ON t1.id = t2.id RIGHT JOIN test_table_join_3 AS t3 USING (id). (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000013f6a64b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1013: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141df0fc 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141ddd52 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5226: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f6638e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 16. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:16:41.418061 [ 30811 ] {b44cbc5a-e180-4abe-9ee1-a2d8e39fa19c} executeQuery: Code: 55. DB::Exception: Method write is not supported by storage Distributed with more than one shard and no sharding key provided. (STORAGE_REQUIRES_PARAMETER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44508) (comment: 01602_insert_into_table_function_cluster.sql) (query 7, line 11) (in query: -- More than one shard, sharding key is necessary INSERT INTO FUNCTION cluster('test_cluster_two_shards_localhost', currentDatabase(), x) SELECT * FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/StorageDistributed.cpp:944: DB::StorageDistributed::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000015c84684 5. /build/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&) @ 0x0000000016bd98a4 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000001484c2eb 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000001484dcd2 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001484f48c 9. /build/src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001485221d 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:16:41.445316 [ 30811 ] {} TCPHandler: Code: 55. DB::Exception: Method write is not supported by storage Distributed with more than one shard and no sharding key provided. (STORAGE_REQUIRES_PARAMETER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/StorageDistributed.cpp:944: DB::StorageDistributed::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000015c84684 5. /build/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&) @ 0x0000000016bd98a4 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000001484c2eb 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000001484dcd2 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001484f48c 9. /build/src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001485221d 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:16:41.449701 [ 11482 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:16:42.708976 [ 30811 ] {47be832a-0184-4c3c-859c-93577889f714} executeQuery: Code: 55. DB::Exception: Method write is not supported by storage Distributed with more than one shard and no sharding key provided. (STORAGE_REQUIRES_PARAMETER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44508) (comment: 01602_insert_into_table_function_cluster.sql) (query 9, line 15) (in query: INSERT INTO FUNCTION remote('127.0.0.{1,2}', currentDatabase(), y, '[HIDDEN]') SELECT * FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/StorageDistributed.cpp:944: DB::StorageDistributed::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000015c84684 5. /build/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&) @ 0x0000000016bd98a4 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000001484c2eb 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000001484dcd2 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001484f48c 9. /build/src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001485221d 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:16:42.765084 [ 30811 ] {} TCPHandler: Code: 55. DB::Exception: Method write is not supported by storage Distributed with more than one shard and no sharding key provided. (STORAGE_REQUIRES_PARAMETER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/StorageDistributed.cpp:944: DB::StorageDistributed::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000015c84684 5. /build/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&) @ 0x0000000016bd98a4 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000001484c2eb 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000001484dcd2 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001484f48c 9. /build/src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001485221d 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:16:44.321401 [ 30862 ] {24ab1093-768f-4f98-a1df-264bb9116d11} executeQuery: Code: 207. DB::Exception: JOIN INNER JOIN ... ON t1.id = t2.id ambiguous identifier 'id'. In scope SELECT id FROM test_table_join_1 AS t1 INNER JOIN test_table_join_2 AS t2 ON t1.id = t2.id FULL OUTER JOIN test_table_join_3 AS t3 USING (id). (AMBIGUOUS_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34138) (comment: 02374_analyzer_join_using.gen.sql) (query 72, line 194) (in query: SELECT id FROM test_table_join_1 AS t1 INNER JOIN test_table_join_2 AS t2 ON t1.id = t2.id FULL JOIN test_table_join_3 AS t3 USING (id);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000013f6a64b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1013: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141df0fc 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141ddd52 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5226: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f6638e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 16. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:16:44.351298 [ 30862 ] {} TCPHandler: Code: 207. DB::Exception: JOIN INNER JOIN ... ON t1.id = t2.id ambiguous identifier 'id'. In scope SELECT id FROM test_table_join_1 AS t1 INNER JOIN test_table_join_2 AS t2 ON t1.id = t2.id FULL OUTER JOIN test_table_join_3 AS t3 USING (id). (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000013f6a64b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1013: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141df0fc 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141ddd52 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5226: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f6638e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 16. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:16:44.797452 [ 31799 ] {007489c4-a9ed-4160-aa13-a87aff19c4d7} DNSResolver: Cannot resolve host (localhos), error 0: Host not found. 2025.07.13 02:16:46.496884 [ 40064 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:16:50.597010 [ 30862 ] {e94a3758-6306-49c9-a7cb-3957b493d976} executeQuery: Code: 207. DB::Exception: JOIN LEFT JOIN ... ON t1.id = t2.id ambiguous identifier 'id'. In scope SELECT id FROM test_table_join_1 AS t1 LEFT JOIN test_table_join_2 AS t2 ON t1.id = t2.id INNER JOIN test_table_join_3 AS t3 USING (id). (AMBIGUOUS_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34138) (comment: 02374_analyzer_join_using.gen.sql) (query 79, line 214) (in query: SELECT id FROM test_table_join_1 AS t1 LEFT JOIN test_table_join_2 AS t2 ON t1.id = t2.id INNER JOIN test_table_join_3 AS t3 USING (id);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000013f6a64b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1013: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141df0fc 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141ddd52 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5226: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f6638e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 16. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:16:50.609284 [ 30862 ] {} TCPHandler: Code: 207. DB::Exception: JOIN LEFT JOIN ... ON t1.id = t2.id ambiguous identifier 'id'. In scope SELECT id FROM test_table_join_1 AS t1 LEFT JOIN test_table_join_2 AS t2 ON t1.id = t2.id INNER JOIN test_table_join_3 AS t3 USING (id). (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000013f6a64b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1013: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141df0fc 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141ddd52 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5226: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f6638e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 16. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:16:51.648448 [ 11482 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:16:52.814190 [ 3894 ] {} DNSResolver: Cannot resolve host (localhos), error 0: Host not found. 2025.07.13 02:16:52.819453 [ 31799 ] {007489c4-a9ed-4160-aa13-a87aff19c4d7} Cluster: Code: 198. DB::NetException: Not found address of host: localhos. (DNS_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000fa99429 3. /build/src/Common/DNSResolver.cpp:113: DB::(anonymous namespace)::hostByName(String const&) @ 0x000000000fa9670f 4. /build/src/Common/DNSResolver.cpp:138: DB::DNSResolver::getResolvedIPAdressessWithFiltering(String const&) @ 0x000000000fa95228 5. /build/src/Common/DNSResolver.cpp:256: DB::DNSResolver::resolveIPAddressWithCache(String const&) @ 0x000000000fa9554c 6. /build/src/Common/DNSResolver.cpp:305: DB::DNSResolver::resolveAddress(String const&, unsigned short) @ 0x000000000fa96233 7. /build/src/Interpreters/Cluster.cpp:82: DB::Cluster::Address::getResolvedAddress() const @ 0x000000001431b9e5 8. /build/src/Interpreters/Cluster.cpp:95: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x000000001431cb0d 9. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Cluster::Address* std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x000000001432a240 10. /build/contrib/llvm-project/libcxx/include/vector:1558: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x0000000014324471 11. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000011701407 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3bbcc 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:16:53.351399 [ 6612 ] {175a33af-406a-4fd0-8585-a0dc96d9837b} executeQuery: Code: 107. DB::ErrnoException: Cannot open file /var/lib/clickhouse/user_files/a: , errno: 2, strerror: No such file or directory: while executing 'FUNCTION file(materialize('a'_String) :: 2) -> file(materialize('a'_String)) String : 1'. (FILE_DOESNT_EXIST) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44968) (comment: 02843_context_has_expired.sql) (query 12, line 29) (in query: SELECT 1 in (SELECT file(materialize('a')));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String&) @ 0x000000000fb766d5 4. /build/src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String&) @ 0x000000000fb76382 5. /build/src/IO/ReadBufferFromFile.cpp:48: DB::ReadBufferFromFile::ReadBufferFromFile(String const&, unsigned long, int, char*, unsigned long, std::optional, std::shared_ptr) @ 0x000000000fb79cec 6. /build/src/Functions/FunctionFile.cpp:140: DB::FunctionFile::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fb79d1 7. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 8. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 11. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 18. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:16:53.371954 [ 6612 ] {} TCPHandler: Code: 107. DB::ErrnoException: Cannot open file /var/lib/clickhouse/user_files/a: , errno: 2, strerror: No such file or directory: while executing 'FUNCTION file(materialize('a'_String) :: 2) -> file(materialize('a'_String)) String : 1'. (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String&) @ 0x000000000fb766d5 4. /build/src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String&) @ 0x000000000fb76382 5. /build/src/IO/ReadBufferFromFile.cpp:48: DB::ReadBufferFromFile::ReadBufferFromFile(String const&, unsigned long, int, char*, unsigned long, std::optional, std::shared_ptr) @ 0x000000000fb79cec 6. /build/src/Functions/FunctionFile.cpp:140: DB::FunctionFile::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fb79d1 7. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 8. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 11. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016b303cc 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 18. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:16:54.712906 [ 37313 ] {360f9d8d-82d7-4110-9a10-b6b859fd4803} 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]:33562) (comment: 03201_variant_null_map_subcolumn.sh) (query 1, line 1) (in query: select v, v.UInt64.null, v.`Array(Variant(String, UInt64))`.null, v.`Array(Variant(String, UInt64))`.size0, v.`Array(Variant(String, UInt64))`.UInt64.null from test order by id format Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbdb1ad 7. /build/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) @ 0x000000001631ac2d 8. /build/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) @ 0x0000000016d5067d 9. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x0000000016d4f5b9 10. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x0000000016d4f3b2 11. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d571cc 12. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016cf6870 13. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:16:54.741808 [ 37313 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbdb1ad 7. /build/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) @ 0x000000001631ac2d 8. /build/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) @ 0x0000000016d5067d 9. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x0000000016d4f5b9 10. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x0000000016d4f3b2 11. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d571cc 12. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016cf6870 13. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:16:55.709240 [ 30862 ] {ced54b50-2b17-4294-85ca-d25b7e2cfeb0} executeQuery: Code: 207. DB::Exception: JOIN LEFT JOIN ... ON t1.id = t2.id ambiguous identifier 'id'. In scope SELECT id FROM test_table_join_1 AS t1 LEFT JOIN test_table_join_2 AS t2 ON t1.id = t2.id LEFT JOIN test_table_join_3 AS t3 USING (id). (AMBIGUOUS_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34138) (comment: 02374_analyzer_join_using.gen.sql) (query 86, line 233) (in query: SELECT id FROM test_table_join_1 AS t1 LEFT JOIN test_table_join_2 AS t2 ON t1.id = t2.id LEFT JOIN test_table_join_3 AS t3 USING (id);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000013f6a64b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1013: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141df0fc 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141ddd52 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5226: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f6638e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 16. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:16:55.716505 [ 30862 ] {} TCPHandler: Code: 207. DB::Exception: JOIN LEFT JOIN ... ON t1.id = t2.id ambiguous identifier 'id'. In scope SELECT id FROM test_table_join_1 AS t1 LEFT JOIN test_table_join_2 AS t2 ON t1.id = t2.id LEFT JOIN test_table_join_3 AS t3 USING (id). (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000013f6a64b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1013: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141df0fc 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141ddd52 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5226: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f6638e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 16. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:16:56.466051 [ 5991 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:16:57.290463 [ 37316 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778c58 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168167bf 10. /build/src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000001680ff45 11. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:16:57.296592 [ 37316 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x0000000016810069 5. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 6. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 2025.07.13 02:16:59.948017 [ 4879 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000013779f8b 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000137794b8 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778bc3 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678d325 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:17:00.849201 [ 30862 ] {f369a2df-d291-4886-b473-172c698b8011} executeQuery: Code: 207. DB::Exception: JOIN LEFT JOIN ... ON t1.id = t2.id ambiguous identifier 'id'. In scope SELECT id FROM test_table_join_1 AS t1 LEFT JOIN test_table_join_2 AS t2 ON t1.id = t2.id RIGHT JOIN test_table_join_3 AS t3 USING (id). (AMBIGUOUS_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34138) (comment: 02374_analyzer_join_using.gen.sql) (query 93, line 252) (in query: SELECT id FROM test_table_join_1 AS t1 LEFT JOIN test_table_join_2 AS t2 ON t1.id = t2.id RIGHT JOIN test_table_join_3 AS t3 USING (id);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000013f6a64b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1013: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141df0fc 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141ddd52 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5226: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f6638e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 16. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:17:00.873082 [ 30862 ] {} TCPHandler: Code: 207. DB::Exception: JOIN LEFT JOIN ... ON t1.id = t2.id ambiguous identifier 'id'. In scope SELECT id FROM test_table_join_1 AS t1 LEFT JOIN test_table_join_2 AS t2 ON t1.id = t2.id RIGHT JOIN test_table_join_3 AS t3 USING (id). (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000013f6a64b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1013: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141df0fc 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141ddd52 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5226: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f6638e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 16. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:17:01.007186 [ 12972 ] {007489c4-a9ed-4160-aa13-a87aff19c4d7} DNSResolver: Cannot resolve host (localhos), error 0: Host not found. 2025.07.13 02:17:01.068799 [ 31799 ] {007489c4-a9ed-4160-aa13-a87aff19c4d7} executeQuery: Code: 279. DB::Exception: All connection tries failed. Log: Code: 198. DB::NetException: Not found address of host: localhos: (localhos:9000). (DNS_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]:44488) (comment: 00965_shard_unresolvable_addresses.sql) (query 5, line 9) (in query: SELECT count() FROM remote('127.0.0.1,localhos', system.one);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000015f79f49 3. /build/src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x0000000016723d86 4. /build/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) @ 0x000000001671b5c5 5. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107] 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&) @ 0x0000000013ae898d 6. /build/src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:se190107] 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&&) @ 0x0000000013ae2fc3 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013adb725 8. /build/src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000013af71c3 9. /build/src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013af6952 10. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013af679a 11. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013af64e1 2025.07.13 02:17:01.088491 [ 31799 ] {} TCPHandler: Code: 279. DB::Exception: All connection tries failed. Log: Code: 198. DB::NetException: Not found address of host: localhos: (localhos:9000). (DNS_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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000015f79f49 3. /build/src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x0000000016723d86 4. /build/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) @ 0x000000001671b5c5 5. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107] 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&) @ 0x0000000013ae898d 6. /build/src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:se190107] 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&&) @ 0x0000000013ae2fc3 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013adb725 8. /build/src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000013af71c3 9. /build/src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013af6952 10. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013af679a 11. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013af64e1 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:17:01.620297 [ 40061 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:17:02.068869 [ 16757 ] {242ba4ed-462f-4c7f-bacf-0d45b03110cf} 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]:48768) (comment: 02500_remove_redundant_distinct.sh) (query 1, line 1) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:02.097416 [ 16757 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:02.543991 [ 37316 ] {21f1962a-0102-4878-9783-dffb31598a71} 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]:48774) (comment: 02500_remove_redundant_distinct.sh) (query 1, line 1) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:02.584191 [ 37316 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:03.026744 [ 37316 ] {24e31dd8-8e18-4206-97a4-be711b3acb08} 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]:48784) (comment: 02500_remove_redundant_distinct.sh) (query 1, line 1) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:03.054804 [ 37316 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:03.516280 [ 37316 ] {1b7da779-0bd3-4005-beab-61aa4fc3b6be} 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]:48796) (comment: 02500_remove_redundant_distinct.sh) (query 1, line 1) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:03.557027 [ 37316 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:03.965444 [ 37316 ] {2cebb8ea-abbc-47d7-8777-3a839c91ff76} 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]:48814) (comment: 02500_remove_redundant_distinct.sh) (query 1, line 1) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:04.008500 [ 37316 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:04.486182 [ 37316 ] {929ea091-e009-442d-8ee0-30d373bd840d} 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]:48826) (comment: 02500_remove_redundant_distinct.sh) (query 1, line 1) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:04.518630 [ 37316 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:05.007571 [ 37316 ] {3cd5ebb8-b9be-418a-a8f6-aebe54ae10d9} 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]:48834) (comment: 02500_remove_redundant_distinct.sh) (query 1, line 1) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:05.083421 [ 37316 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:05.443763 [ 37316 ] {2b4c9d6c-a2fa-4ae7-95db-9e7112b48ce6} 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]:48848) (comment: 02500_remove_redundant_distinct.sh) (query 1, line 1) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:05.483288 [ 37316 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:05.900711 [ 16757 ] {0e663e63-0eb5-4515-830b-78698ef03718} 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]:48860) (comment: 02500_remove_redundant_distinct.sh) (query 1, line 1) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:05.938678 [ 16757 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:06.466691 [ 16757 ] {e77d0225-d0a4-4870-b9db-71c783f89e2b} 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]:48864) (comment: 02500_remove_redundant_distinct.sh) (query 1, line 1) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:06.523281 [ 16757 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:06.886019 [ 12972 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:17:06.962612 [ 16757 ] {1db661da-631c-4e3b-9202-4863041ca6b4} 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]:48868) (comment: 02500_remove_redundant_distinct.sh) (query 1, line 1) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:06.989711 [ 16757 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:07.090520 [ 30862 ] {7fc42bfd-b292-46d0-96ff-0aab6825b434} executeQuery: Code: 207. DB::Exception: JOIN LEFT JOIN ... ON t1.id = t2.id ambiguous identifier 'id'. In scope SELECT id FROM test_table_join_1 AS t1 LEFT JOIN test_table_join_2 AS t2 ON t1.id = t2.id FULL OUTER JOIN test_table_join_3 AS t3 USING (id). (AMBIGUOUS_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34138) (comment: 02374_analyzer_join_using.gen.sql) (query 100, line 271) (in query: SELECT id FROM test_table_join_1 AS t1 LEFT JOIN test_table_join_2 AS t2 ON t1.id = t2.id FULL JOIN test_table_join_3 AS t3 USING (id);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000013f6a64b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1013: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141df0fc 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141ddd52 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5226: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f6638e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 16. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:17:07.108563 [ 30862 ] {} TCPHandler: Code: 207. DB::Exception: JOIN LEFT JOIN ... ON t1.id = t2.id ambiguous identifier 'id'. In scope SELECT id FROM test_table_join_1 AS t1 LEFT JOIN test_table_join_2 AS t2 ON t1.id = t2.id FULL OUTER JOIN test_table_join_3 AS t3 USING (id). (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000013f6a64b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1013: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141df0fc 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141ddd52 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5226: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f6638e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 16. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:17:07.419085 [ 16757 ] {7fb8adaa-bf4e-4181-864e-f98f013d90a8} 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]:48878) (comment: 02500_remove_redundant_distinct.sh) (query 1, line 1) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:07.459473 [ 16757 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:07.982082 [ 16757 ] {a0cd8c6c-3116-4289-afd4-6be9bd3ed5ae} 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]:48880) (comment: 02500_remove_redundant_distinct.sh) (query 1, line 1) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:08.015485 [ 16757 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:08.444970 [ 16757 ] {d16c6835-928b-478a-a1a5-900e8e1a4918} 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]:48888) (comment: 02500_remove_redundant_distinct.sh) (query 1, line 1) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:08.473851 [ 16757 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:08.815166 [ 3690 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda7a6 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000118cbf6e 8. /build/src/Interpreters/DatabaseCatalog.cpp:1360: DB::DatabaseCatalog::dropTablesParallel(std::vector, std::allocator>>) @ 0x0000000014421059 9. /build/src/Interpreters/DatabaseCatalog.cpp:1382: DB::DatabaseCatalog::dropTableDataTask() @ 0x000000001442155c 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013882414 11. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000138854aa 12. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000013885c47 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 14. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:17:09.109187 [ 16757 ] {2eabe7a8-cf54-43fc-a412-e479886074fc} 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]:43232) (comment: 02500_remove_redundant_distinct.sh) (query 1, line 1) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:09.131954 [ 16757 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:09.244971 [ 31799 ] {786033b6-31f3-4393-8002-e0d1737bc039} DNSResolver: Cannot resolve host (localhos), error 0: Host not found. 2025.07.13 02:17:09.514182 [ 16757 ] {52a61fec-9c35-48ee-acc0-882e84d917b4} 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]:43244) (comment: 02500_remove_redundant_distinct.sh) (query 1, line 1) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:09.561202 [ 16757 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:09.895759 [ 16757 ] {a9f1df32-c7b2-45d8-aef4-10ebe7f454dc} 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]:43258) (comment: 02500_remove_redundant_distinct.sh) (query 1, line 1) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:09.905021 [ 16757 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:10.267289 [ 16757 ] {6dd364dc-be1f-42b0-9028-0fad1519e404} 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]:43274) (comment: 02500_remove_redundant_distinct.sh) (query 1, line 1) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:10.294900 [ 16757 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:10.985375 [ 16757 ] {10caac00-ad2f-4cc4-b354-0adf3d479cd0} 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]:43284) (comment: 02500_remove_redundant_distinct.sh) (query 1, line 1) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:11.015012 [ 16757 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:11.466964 [ 16757 ] {c95719b3-e4c3-4b51-a79a-18600ecb4c4b} 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]:43300) (comment: 02500_remove_redundant_distinct.sh) (query 1, line 1) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:11.500688 [ 16757 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:11.746508 [ 5071 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:17:12.026322 [ 16757 ] {8d70e349-60f4-4711-8222-b5f0deb6c26f} 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]:43308) (comment: 02500_remove_redundant_distinct.sh) (query 1, line 1) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:12.053194 [ 16757 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:12.356013 [ 30862 ] {7df59655-8ca5-440d-b3a9-83216af45ecd} executeQuery: Code: 207. DB::Exception: JOIN RIGHT JOIN ... ON t1.id = t2.id ambiguous identifier 'id'. In scope SELECT id FROM test_table_join_1 AS t1 RIGHT JOIN test_table_join_2 AS t2 ON t1.id = t2.id INNER JOIN test_table_join_3 AS t3 USING (id). (AMBIGUOUS_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34138) (comment: 02374_analyzer_join_using.gen.sql) (query 107, line 291) (in query: SELECT id FROM test_table_join_1 AS t1 RIGHT JOIN test_table_join_2 AS t2 ON t1.id = t2.id INNER JOIN test_table_join_3 AS t3 USING (id);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000013f6a64b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1013: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141df0fc 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141ddd52 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5226: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f6638e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 16. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:17:12.377343 [ 30862 ] {} TCPHandler: Code: 207. DB::Exception: JOIN RIGHT JOIN ... ON t1.id = t2.id ambiguous identifier 'id'. In scope SELECT id FROM test_table_join_1 AS t1 RIGHT JOIN test_table_join_2 AS t2 ON t1.id = t2.id INNER JOIN test_table_join_3 AS t3 USING (id). (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000013f6a64b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1013: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141df0fc 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141ddd52 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5226: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f6638e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 16. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:17:12.494890 [ 16757 ] {7cf226ce-7dd9-4e62-9712-eee3434b3e07} 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]:43324) (comment: 02500_remove_redundant_distinct.sh) (query 1, line 1) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:12.531530 [ 16757 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:13.037133 [ 5015 ] {d956782a-9640-45f4-8151-94e64b5de4bd} 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]:43340) (comment: 02500_remove_redundant_distinct.sh) (query 1, line 1) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:13.063346 [ 5015 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:13.502661 [ 5015 ] {bb7af0ff-713c-421f-b6bc-afc2c6ee3966} 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]:43364) (comment: 02500_remove_redundant_distinct.sh) (query 1, line 1) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:13.523371 [ 5015 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:14.049698 [ 5015 ] {9e9806fa-698a-4e2f-ae2f-fc9597974dd0} 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]:43378) (comment: 02500_remove_redundant_distinct.sh) (query 1, line 1) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:14.109215 [ 5015 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:14.678633 [ 16757 ] {5a99f164-fb6b-4d2f-9685-820d6d65ee0e} 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]:43382) (comment: 02500_remove_redundant_distinct.sh) (query 1, line 1) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:14.703599 [ 16757 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:15.133586 [ 37313 ] {de3cf93b-e47b-404f-8fab-7e23c04967f6} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 4.95 MiB (attempt to allocate chunk of 1.83 MiB), maximum: 9.31 GiB: while executing 'FUNCTION bitXor(number : 0, bitShiftRight(__table2.number, 33_UInt8) :: 7) -> bitXor(__table2.number, bitShiftRight(__table2.number, 33_UInt8)) UInt64 : 8'. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33624) (comment: 00973_uniq_non_associativity.sql) (query 7, line 51) (in query: /* Occupy 10 cells near the end of "a": * a: [ ----------- ] * c: [ -- ] * If we insert "a" then "c", these values will be placed at the end of hash table due to collision resolution: * a + c: [ aaaaaaaaaaacc] */ CREATE TABLE part_c ENGINE = TinyLog AS SELECT * FROM ( WITH number AS k1, bitXor(k1, bitShiftRight(k1, 33)) AS k2, k2 * 0xff51afd7ed558ccd AS k3, bitXor(k3, bitShiftRight(k3, 33)) AS k4, k4 * 0xc4ceb9fe1a85ec53 AS k5, bitXor(k5, bitShiftRight(k5, 33)) AS k6, k6 AS hash, bitShiftRight(hash, 15) % 0x20000 AS place, hash % 2 = 0 AS will_remain SELECT hash, number, place FROM system.numbers WHERE place >= 131052 AND place < 131062 AND will_remain AND hash NOT IN (SELECT hash FROM part_a) LIMIT 1 BY place LIMIT 10 ) ORDER BY place;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x000000000fb2dd39 4. /build/src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2cb67 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2c5bf 6. /build/src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000fa9410c 7. /build/src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000000fa92864 8. /build/src/Common/PODArray.h:118: void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000009fb12e4 9. /build/src/Functions/FunctionBinaryArithmetic.h:2323: _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_110BitXorImplENS12_10NameBitXorELb1ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clIS5_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000000b0cc522 10. /build/src/Functions/FunctionBinaryArithmetic.h:838: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b0b3155 11. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b0b1a57 12. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 13. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 17. /build/src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000016b34094 18. /build/src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000016b33fb4 19. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 20. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 21. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 22. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 23. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 24. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 25. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 26. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168cfe81 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 28. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:17:15.224513 [ 37313 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 4.95 MiB (attempt to allocate chunk of 1.83 MiB), maximum: 9.31 GiB: while executing 'FUNCTION bitXor(number : 0, bitShiftRight(__table2.number, 33_UInt8) :: 7) -> bitXor(__table2.number, bitShiftRight(__table2.number, 33_UInt8)) UInt64 : 8'. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x000000000fb2dd39 4. /build/src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2cb67 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2c5bf 6. /build/src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000fa9410c 7. /build/src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000000fa92864 8. /build/src/Common/PODArray.h:118: void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000009fb12e4 9. /build/src/Functions/FunctionBinaryArithmetic.h:2323: _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_110BitXorImplENS12_10NameBitXorELb1ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clIS5_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000000b0cc522 10. /build/src/Functions/FunctionBinaryArithmetic.h:838: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b0b3155 11. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b0b1a57 12. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 13. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 16. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 17. /build/src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000016b34094 18. /build/src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000016b33fb4 19. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000119864d3 20. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000168c04a0 21. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 22. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 23. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 24. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 25. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 26. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168cfe81 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 28. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x00000000168cf907 5. /build/src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000001680710e 6. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 2025.07.13 02:17:15.373208 [ 16763 ] {ee605da5-7e2a-402b-8fe8-ed5c68098c04} 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]:53114) (comment: 00205_emptyscalar_subquery_type_mismatch_bug.sql) (in query: DROP DATABASE IF EXISTS test_4orqfr38 SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:17:15.376656 [ 16757 ] {39953af4-8212-4a33-9767-cd4c62a98af3} 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]:43410) (comment: 02500_remove_redundant_distinct.sh) (query 1, line 1) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:15.386115 [ 16763 ] {ee605da5-7e2a-402b-8fe8-ed5c68098c04} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:17:15.413526 [ 16757 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:15.918645 [ 5015 ] {be172db1-1adc-4c6d-a8f7-dc8f687752b6} executeQuery: Code: 215. DB::Exception: Column mn is not under aggregate function and not in GROUP BY keys. In query SELECT n, number + 5 AS inter FROM (SELECT toFloat32(number % 10) AS n, number, number * 2 AS mn FROM numbers(10) WHERE (number % 3) = 1) GROUP BY n, inter ORDER BY n ASC WITH FILL FROM 0 TO 5.51 STEP 0.5 INTERPOLATE ( inter AS mn * 2 ). (NOT_AN_AGGREGATE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43396) (comment: 03155_analyzer_interpolate.sql) (query 3, line 9) (in query: SELECT n, number+5 AS inter FROM ( -- { serverError NOT_AN_AGGREGATE } SELECT toFloat32(number % 10) AS n, number, number*2 AS mn FROM numbers(10) WHERE number % 3 = 1 ) GROUP BY n, inter ORDER BY n WITH FILL FROM 0 TO 5.51 STEP 0.5 INTERPOLATE (inter AS mn * 2);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Analyzer/ValidationUtils.cpp:199: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000013f86ce9 5. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000013f86917 6. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000013f86917 7. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000013f86917 8. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000013f86917 9. /build/src/Analyzer/ValidationUtils.cpp:357: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000013f85f67 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f332a5 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:17:15.923549 [ 16763 ] {e7e8b254-d153-49d9-806d-c0bcc91d26fb} 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]:43438) (comment: 02500_remove_redundant_distinct.sh) (query 1, line 1) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:15.948196 [ 5015 ] {} TCPHandler: Code: 215. DB::Exception: Column mn is not under aggregate function and not in GROUP BY keys. In query SELECT n, number + 5 AS inter FROM (SELECT toFloat32(number % 10) AS n, number, number * 2 AS mn FROM numbers(10) WHERE (number % 3) = 1) GROUP BY n, inter ORDER BY n ASC WITH FILL FROM 0 TO 5.51 STEP 0.5 INTERPOLATE ( inter AS mn * 2 ). (NOT_AN_AGGREGATE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Analyzer/ValidationUtils.cpp:199: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000013f86ce9 5. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000013f86917 6. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000013f86917 7. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000013f86917 8. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000013f86917 9. /build/src/Analyzer/ValidationUtils.cpp:357: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000013f85f67 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f332a5 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:17:15.955640 [ 16763 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:16.436366 [ 4922 ] {6eaa12e6-c0a5-4bc1-b479-a196b16c4f41} 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]:43454) (comment: 02500_remove_redundant_distinct.sh) (query 1, line 1) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:16.479636 [ 4922 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:16.829926 [ 12975 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:17:16.977823 [ 27539 ] {d9cb861b-ed9e-46fa-bcd3-e8df17b90ab4} 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]:43488) (comment: 02500_remove_redundant_distinct.sh) (query 1, line 1) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:17.020435 [ 27539 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:17.314294 [ 4000 ] {} DNSResolver: Cannot resolve host (localhos), error 0: Host not found. 2025.07.13 02:17:17.324829 [ 31799 ] {786033b6-31f3-4393-8002-e0d1737bc039} Cluster: Code: 198. DB::NetException: Not found address of host: localhos. (DNS_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000fa99429 3. /build/src/Common/DNSResolver.cpp:113: DB::(anonymous namespace)::hostByName(String const&) @ 0x000000000fa9670f 4. /build/src/Common/DNSResolver.cpp:138: DB::DNSResolver::getResolvedIPAdressessWithFiltering(String const&) @ 0x000000000fa95228 5. /build/src/Common/DNSResolver.cpp:256: DB::DNSResolver::resolveIPAddressWithCache(String const&) @ 0x000000000fa9554c 6. /build/src/Common/DNSResolver.cpp:305: DB::DNSResolver::resolveAddress(String const&, unsigned short) @ 0x000000000fa96233 7. /build/src/Interpreters/Cluster.cpp:82: DB::Cluster::Address::getResolvedAddress() const @ 0x000000001431b9e5 8. /build/src/Interpreters/Cluster.cpp:95: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x000000001431cb0d 9. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Cluster::Address* std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x000000001432a240 10. /build/contrib/llvm-project/libcxx/include/vector:1558: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x0000000014324471 11. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000011701407 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3bbcc 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:17:17.560896 [ 27539 ] {34b771ec-5b4c-4fc7-bcbe-630bfe10552f} 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]:43494) (comment: 02500_remove_redundant_distinct.sh) (query 1, line 1) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:17.597522 [ 27539 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:18.069951 [ 4922 ] {8df31657-0c74-41a3-ade8-4fae1481de80} 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]:43506) (comment: 02500_remove_redundant_distinct.sh) (query 1, line 1) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:18.103339 [ 4922 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:18.256141 [ 16758 ] {790b7e5b-f9eb-45dc-a361-e22f36623e03} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 60158.823581 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45688) (comment: 02455_one_row_from_csv_memory_usage.sh) (query 1, line 1) (in query: SELECT * FROM file('test_11_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=100000000), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x0000000013ad84ab 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x0000000013ad77ec 5. /build/src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x000000001496af1f 6. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000168d1a5a 7. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0c24 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 2025.07.13 02:17:18.619136 [ 4922 ] {504a49a1-8442-432a-a942-481c4ee4fd5e} 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]:43514) (comment: 02500_remove_redundant_distinct.sh) (query 1, line 1) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:18.653677 [ 4922 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:18.747327 [ 30862 ] {ebec7a19-23bb-4b88-af01-9b5f313a85db} executeQuery: Code: 207. DB::Exception: JOIN RIGHT JOIN ... ON t1.id = t2.id ambiguous identifier 'id'. In scope SELECT id FROM test_table_join_1 AS t1 RIGHT JOIN test_table_join_2 AS t2 ON t1.id = t2.id LEFT JOIN test_table_join_3 AS t3 USING (id). (AMBIGUOUS_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34138) (comment: 02374_analyzer_join_using.gen.sql) (query 114, line 310) (in query: SELECT id FROM test_table_join_1 AS t1 RIGHT JOIN test_table_join_2 AS t2 ON t1.id = t2.id LEFT JOIN test_table_join_3 AS t3 USING (id);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000013f6a64b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1013: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141df0fc 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141ddd52 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5226: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f6638e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 16. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:17:18.787746 [ 30862 ] {} TCPHandler: Code: 207. DB::Exception: JOIN RIGHT JOIN ... ON t1.id = t2.id ambiguous identifier 'id'. In scope SELECT id FROM test_table_join_1 AS t1 RIGHT JOIN test_table_join_2 AS t2 ON t1.id = t2.id LEFT JOIN test_table_join_3 AS t3 USING (id). (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000013f6a64b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1013: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141df0fc 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141ddd52 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5226: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f6638e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 16. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:17:18.911710 [ 16758 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 60158.823581 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x0000000013ad84ab 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x0000000013ad77ec 5. /build/src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x000000001496af1f 6. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000168d1a5a 7. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0c24 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:17:19.124583 [ 4930 ] {950d1820-3a96-4496-9ae5-10b8821debc5} 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]:35560) (comment: 02500_remove_redundant_distinct.sh) (query 1, line 1) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:19.145754 [ 4930 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:19.811480 [ 4930 ] {9d9442c1-e558-4d9d-bb62-18cc990c4af7} 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]:35578) (comment: 02500_remove_redundant_distinct.sh) (query 1, line 1) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:19.834873 [ 4930 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:20.122733 [ 16757 ] {a2707294-6e24-48df-a4f1-001ff4552d0d} executeQuery: Code: 1. DB::Exception: Function 'in' is supported only if second argument is constant or table expression. (UNSUPPORTED_METHOD) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43422) (comment: 00936_function_result_with_operator_in.sql) (query 12, line 24) (in query: -- non-constant expressions in the right side of IN SELECT count() FROM samples WHERE 1 IN range(samples.value);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Planner/CollectSets.cpp:117: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x00000000141f124e 5. /build/src/Analyzer/InDepthQueryTreeVisitor.h:63: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x00000000141f03b0 6. /build/src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x00000000141f0344 7. /build/src/Planner/Planner.cpp:1485: DB::Planner::buildPlanForQueryNode() @ 0x000000001489732c 8. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 10. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:17:20.142160 [ 16757 ] {} TCPHandler: Code: 1. DB::Exception: Function 'in' is supported only if second argument is constant or table expression. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Planner/CollectSets.cpp:117: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x00000000141f124e 5. /build/src/Analyzer/InDepthQueryTreeVisitor.h:63: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x00000000141f03b0 6. /build/src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x00000000141f0344 7. /build/src/Planner/Planner.cpp:1485: DB::Planner::buildPlanForQueryNode() @ 0x000000001489732c 8. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 10. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:17:20.256887 [ 16757 ] {7fc433f5-39b0-46c2-8c5b-04f2cbc8de8a} executeQuery: Code: 1. DB::Exception: Function 'in' is supported only if second argument is constant or table expression. (UNSUPPORTED_METHOD) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43422) (comment: 00936_function_result_with_operator_in.sql) (query 13, line 26) (in query: SELECT count() FROM samples WHERE 1 IN range(rand() % 1000);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Planner/CollectSets.cpp:117: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x00000000141f124e 5. /build/src/Analyzer/InDepthQueryTreeVisitor.h:63: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x00000000141f03b0 6. /build/src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x00000000141f0344 7. /build/src/Planner/Planner.cpp:1485: DB::Planner::buildPlanForQueryNode() @ 0x000000001489732c 8. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 10. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:17:20.264627 [ 16757 ] {} TCPHandler: Code: 1. DB::Exception: Function 'in' is supported only if second argument is constant or table expression. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Planner/CollectSets.cpp:117: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x00000000141f124e 5. /build/src/Analyzer/InDepthQueryTreeVisitor.h:63: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x00000000141f03b0 6. /build/src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x00000000141f0344 7. /build/src/Planner/Planner.cpp:1485: DB::Planner::buildPlanForQueryNode() @ 0x000000001489732c 8. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 10. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:17:20.377921 [ 6608 ] {b520bd4a-cc52-4d9e-824f-e5003a36f769} 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]:35618) (comment: 02500_remove_redundant_distinct.sh) (query 1, line 1) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:20.427602 [ 6608 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:20.597441 [ 16757 ] {2a3d0cb8-d0af-47d3-a890-dafb53e9c793} executeQuery: Code: 277. DB::Exception: Primary key (key) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43422) (comment: 00936_function_result_with_operator_in.sql) (query 14, line 28) (in query: -- index is not used SELECT count() FROM samples WHERE value IN range(3);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/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>&&) @ 0x0000000015ce57cb 4. /build/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) @ 0x0000000016d4fa3f 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x0000000016d4f5b9 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x0000000016d4f3b2 7. /build/src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:612: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x0000000016df9dfe 8. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:196: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1c92 9. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 14. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 15. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 20. ? @ 0x00007f7210eb6ac3 21. ? @ 0x00007f7210f48850 2025.07.13 02:17:20.621791 [ 16757 ] {} TCPHandler: Code: 277. DB::Exception: Primary key (key) 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/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>&&) @ 0x0000000015ce57cb 4. /build/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) @ 0x0000000016d4fa3f 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x0000000016d4f5b9 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x0000000016d4f3b2 7. /build/src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:612: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x0000000016df9dfe 8. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:196: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1c92 9. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 14. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 15. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 20. ? @ 0x00007f7210eb6ac3 21. ? @ 0x00007f7210f48850 2025.07.13 02:17:20.967219 [ 4930 ] {1a24b3c8-2db2-4038-918a-f4ab2b507c7c} 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]:35628) (comment: 02500_remove_redundant_distinct.sh) (query 1, line 1) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:21.006515 [ 4930 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000013778b53 7. /build/src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014355749 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000001490116a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:21.057657 [ 16757 ] {59bb3ad7-7d0e-48a8-813d-18b3dec362bd} executeQuery: Code: 53. DB::Exception: Cannot convert string 'ab' to type UInt8. (TYPE_MISMATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:43422) (comment: 00936_function_result_with_operator_in.sql) (query 15, line 31) (in query: -- wrong type SELECT 123 IN splitByChar('c', 'abcdef');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014b78237 5. /build/src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014b75587 6. /build/src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x0000000014b787c3 7. /build/src/Analyzer/SetUtils.cpp:69: DB::(anonymous namespace)::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x00000000141e85e5 8. /build/src/Analyzer/SetUtils.cpp:99: std::vector> DB::(anonymous namespace)::createBlockFromCollection(DB::Array const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, DB::GetSetElementParams) @ 0x00000000141e73ee 9. /build/src/Analyzer/SetUtils.cpp:196: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x00000000141e668c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3511: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f526bd 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:17:21.077045 [ 16757 ] {} TCPHandler: Code: 53. DB::Exception: Cannot convert string 'ab' to type UInt8. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a5b694b 4. /build/src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014b78237 5. /build/src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014b75587 6. /build/src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x0000000014b787c3 7. /build/src/Analyzer/SetUtils.cpp:69: DB::(anonymous namespace)::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x00000000141e85e5 8. /build/src/Analyzer/SetUtils.cpp:99: std::vector> DB::(anonymous namespace)::createBlockFromCollection(DB::Array const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, DB::GetSetElementParams) @ 0x00000000141e73ee 9. /build/src/Analyzer/SetUtils.cpp:196: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x00000000141e668c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3511: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f526bd 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:17:21.819562 [ 40061 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:17:22.571000 [ 4274 ] {d42d0d2a-4cb4-454f-94d1-77355c91d7e5::all_1_1_0_2} 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:17:22.589132 [ 4274 ] {d42d0d2a-4cb4-454f-94d1-77355c91d7e5::all_1_1_0_2} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 9. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000001494103a 7. /build/src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000016450695 8. /build/src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x000000001644fcf1 9. /build/src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x0000000016594cb8 10. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 11. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 13. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:17:22.591640 [ 4274 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {d42d0d2a-4cb4-454f-94d1-77355c91d7e5::all_1_1_0_2}: 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 9. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000001494103a 7. /build/src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000016450695 8. /build/src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x000000001644fcf1 9. /build/src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x0000000016594cb8 10. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 11. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 13. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:17:22.731269 [ 30811 ] {6d67f441-9b7f-4062-8bb9-7a0cac5e7b00} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_2.txt' with part 'all_1_1_0' reason: '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))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Storages/MergeTree/MergeTreeMutationStatus.cpp:33: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x000000001639ba0e 2. /build/src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000001655dce8 3. /build/src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000001655ed84 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd3ec 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/InterpreterDeleteQuery.cpp:140: DB::InterpreterDeleteQuery::execute() @ 0x0000000014c1eaad 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 12. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 13. /build/src/Interpreters/InterpreterDeleteQuery.cpp:79: DB::InterpreterDeleteQuery::execute() @ 0x0000000014c1dc0d 14. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 15. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 16. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 17. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 22. ? @ 0x00007f7210eb6ac3 23. ? @ 0x00007f7210f48850 . (UNFINISHED) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 03033_lightweight_deletes_sync.sql) (in query: /* ddl_entry=query-0000000198 */ DELETE FROM test_11.t_lightweight_deletes WHERE a = 1 SETTINGS lightweight_deletes_sync = 2), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&, String&&) @ 0x000000001639bb59 4. /build/src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x000000001639ba6d 5. /build/src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000001655dce8 6. /build/src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000001655ed84 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd3ec 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 9. /build/src/Interpreters/InterpreterDeleteQuery.cpp:140: DB::InterpreterDeleteQuery::execute() @ 0x0000000014c1eaad 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 12. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 13. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 14. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 15. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 16. /build/src/Interpreters/InterpreterDeleteQuery.cpp:79: DB::InterpreterDeleteQuery::execute() @ 0x0000000014c1dc0d 17. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 19. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 20. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 2025.07.13 02:17:22.886611 [ 30811 ] {6d67f441-9b7f-4062-8bb9-7a0cac5e7b00} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_2.txt' with part 'all_1_1_0' reason: '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))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Storages/MergeTree/MergeTreeMutationStatus.cpp:33: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x000000001639ba0e 2. /build/src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000001655dce8 3. /build/src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000001655ed84 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd3ec 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/InterpreterDeleteQuery.cpp:140: DB::InterpreterDeleteQuery::execute() @ 0x0000000014c1eaad 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 12. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 13. /build/src/Interpreters/InterpreterDeleteQuery.cpp:79: DB::InterpreterDeleteQuery::execute() @ 0x0000000014c1dc0d 14. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 15. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 16. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 17. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 22. ? @ 0x00007f7210eb6ac3 23. ? @ 0x00007f7210f48850 . (UNFINISHED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35576) (comment: 03033_lightweight_deletes_sync.sql) (query 4, line 7) (in query: DELETE FROM t_lightweight_deletes WHERE a = 1 SETTINGS lightweight_deletes_sync = 2;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&, String&&) @ 0x000000001639bb59 4. /build/src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x000000001639ba6d 5. /build/src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000001655dce8 6. /build/src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000001655ed84 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd3ec 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 9. /build/src/Interpreters/InterpreterDeleteQuery.cpp:140: DB::InterpreterDeleteQuery::execute() @ 0x0000000014c1eaad 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 12. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 13. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 14. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 15. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 16. /build/src/Interpreters/InterpreterDeleteQuery.cpp:79: DB::InterpreterDeleteQuery::execute() @ 0x0000000014c1dc0d 17. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 19. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 20. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 2025.07.13 02:17:22.933614 [ 30811 ] {} TCPHandler: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_2.txt' with part 'all_1_1_0' reason: '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))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Storages/MergeTree/MergeTreeMutationStatus.cpp:33: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x000000001639ba0e 2. /build/src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000001655dce8 3. /build/src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000001655ed84 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd3ec 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 6. /build/src/Interpreters/InterpreterDeleteQuery.cpp:140: DB::InterpreterDeleteQuery::execute() @ 0x0000000014c1eaad 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 12. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 13. /build/src/Interpreters/InterpreterDeleteQuery.cpp:79: DB::InterpreterDeleteQuery::execute() @ 0x0000000014c1dc0d 14. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 15. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 16. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 17. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 22. ? @ 0x00007f7210eb6ac3 23. ? @ 0x00007f7210f48850 . (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&, String&&) @ 0x000000001639bb59 4. /build/src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x000000001639ba6d 5. /build/src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000001655dce8 6. /build/src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000001655ed84 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd3ec 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 9. /build/src/Interpreters/InterpreterDeleteQuery.cpp:140: DB::InterpreterDeleteQuery::execute() @ 0x0000000014c1eaad 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 12. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 13. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 14. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 15. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 16. /build/src/Interpreters/InterpreterDeleteQuery.cpp:79: DB::InterpreterDeleteQuery::execute() @ 0x0000000014c1dc0d 17. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 19. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 20. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 2025.07.13 02:17:25.303054 [ 30862 ] {f9a893c0-43c6-4dda-a4f5-61ec043b908c} executeQuery: Code: 207. DB::Exception: JOIN RIGHT JOIN ... ON t1.id = t2.id ambiguous identifier 'id'. In scope SELECT id FROM test_table_join_1 AS t1 RIGHT JOIN test_table_join_2 AS t2 ON t1.id = t2.id RIGHT JOIN test_table_join_3 AS t3 USING (id). (AMBIGUOUS_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34138) (comment: 02374_analyzer_join_using.gen.sql) (query 121, line 329) (in query: SELECT id FROM test_table_join_1 AS t1 RIGHT JOIN test_table_join_2 AS t2 ON t1.id = t2.id RIGHT JOIN test_table_join_3 AS t3 USING (id);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000013f6a64b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1013: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141df0fc 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141ddd52 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5226: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f6638e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 16. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:17:25.313037 [ 30862 ] {} TCPHandler: Code: 207. DB::Exception: JOIN RIGHT JOIN ... ON t1.id = t2.id ambiguous identifier 'id'. In scope SELECT id FROM test_table_join_1 AS t1 RIGHT JOIN test_table_join_2 AS t2 ON t1.id = t2.id RIGHT JOIN test_table_join_3 AS t3 USING (id). (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000013f6a64b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1013: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141df0fc 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141ddd52 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5226: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f6638e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 16. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:17:26.332881 [ 31788 ] {b1709086-d03d-41bb-a9f9-20b80d12ae44} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:45674) (comment: 01073_show_tables_not_like.sql) (query 25, line 30) (in query: DROP DATABASE test_9), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/IStorage.cpp:171: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015c3ce9a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833683 6. /build/src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835a47 7. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 8. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 9. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:17:26.376998 [ 31788 ] {} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/IStorage.cpp:171: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015c3ce9a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833683 6. /build/src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835a47 7. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 8. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 9. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:17:26.932246 [ 40065 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:17:30.911490 [ 30862 ] {665b25a5-1a31-46e8-a6a7-d78b3f322737} executeQuery: Code: 207. DB::Exception: JOIN RIGHT JOIN ... ON t1.id = t2.id ambiguous identifier 'id'. In scope SELECT id FROM test_table_join_1 AS t1 RIGHT JOIN test_table_join_2 AS t2 ON t1.id = t2.id FULL OUTER JOIN test_table_join_3 AS t3 USING (id). (AMBIGUOUS_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34138) (comment: 02374_analyzer_join_using.gen.sql) (query 128, line 348) (in query: SELECT id FROM test_table_join_1 AS t1 RIGHT JOIN test_table_join_2 AS t2 ON t1.id = t2.id FULL JOIN test_table_join_3 AS t3 USING (id);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000013f6a64b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1013: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141df0fc 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141ddd52 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5226: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f6638e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 16. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:17:30.921746 [ 30862 ] {} TCPHandler: Code: 207. DB::Exception: JOIN RIGHT JOIN ... ON t1.id = t2.id ambiguous identifier 'id'. In scope SELECT id FROM test_table_join_1 AS t1 RIGHT JOIN test_table_join_2 AS t2 ON t1.id = t2.id FULL OUTER JOIN test_table_join_3 AS t3 USING (id). (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000013f6a64b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1013: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141df0fc 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141ddd52 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5226: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f6638e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 16. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:17:31.300290 [ 6612 ] {3b78c488-1cbc-4206-b887-d82c86e7dc31} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt32)' because Variant type is not allowed. Set setting enable_variant_type = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57346) (comment: 03215_validate_type_in_alter_add_modify_column.sql) (query 7, line 8) (in query: alter table test add column bad Variant(UInt32, String);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:105: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014bec824 5. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014bebe9f 6. /build/src/Storages/AlterCommands.cpp:1445: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015c123c0 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fcff4 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:31.328558 [ 6612 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt32)' because Variant type is not allowed. Set setting enable_variant_type = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:105: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014bec824 5. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014bebe9f 6. /build/src/Storages/AlterCommands.cpp:1445: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015c123c0 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fcff4 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:31.493328 [ 6612 ] {994daca1-50af-4388-8c9b-885d79ac41a4} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Dynamic' because Dynamic type is not allowed. Set setting enable_dynamic_type = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57346) (comment: 03215_validate_type_in_alter_add_modify_column.sql) (query 8, line 9) (in query: alter table test add column bad Dynamic;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:149: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014bec8c0 5. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014bebe9f 6. /build/src/Storages/AlterCommands.cpp:1445: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015c123c0 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fcff4 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:31.543953 [ 6612 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Dynamic' because Dynamic type is not allowed. Set setting enable_dynamic_type = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:149: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014bec8c0 5. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014bebe9f 6. /build/src/Storages/AlterCommands.cpp:1445: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015c123c0 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fcff4 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:31.730354 [ 6612 ] {35abe7ea-114d-42de-ac19-98a2585e0a8c} executeQuery: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt8) is prohibited by default due to expected negative impact on performance. It can be enabled with the `allow_suspicious_low_cardinality_types` setting. (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57346) (comment: 03215_validate_type_in_alter_add_modify_column.sql) (query 9, line 10) (in query: alter table test add column bad LowCardinality(UInt8);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:67: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014becaab 5. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014bebe9f 6. /build/src/Storages/AlterCommands.cpp:1445: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015c123c0 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fcff4 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:31.745117 [ 6612 ] {} TCPHandler: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt8) is prohibited by default due to expected negative impact on performance. It can be enabled with the `allow_suspicious_low_cardinality_types` setting. (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:67: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014becaab 5. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014bebe9f 6. /build/src/Storages/AlterCommands.cpp:1445: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015c123c0 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fcff4 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:31.896089 [ 4626 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:17:31.941811 [ 6612 ] {44dbc386-d4de-403f-bb44-2c56a21587d8} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(10000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57346) (comment: 03215_validate_type_in_alter_add_modify_column.sql) (query 10, line 11) (in query: alter table test add column bad FixedString(10000);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000a309b0b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014bec95f 5. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014bebe9f 6. /build/src/Storages/AlterCommands.cpp:1445: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015c123c0 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fcff4 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:31.967508 [ 6612 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(10000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000a309b0b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014bec95f 5. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014bebe9f 6. /build/src/Storages/AlterCommands.cpp:1445: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015c123c0 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fcff4 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:32.234196 [ 6612 ] {9784170e-d37a-4bc9-bee5-9cab0cd27183} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt32)' because Variant type is not allowed. Set setting enable_variant_type = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57346) (comment: 03215_validate_type_in_alter_add_modify_column.sql) (query 11, line 13) (in query: alter table test modify column id Variant(UInt32, String);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:105: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014bec824 5. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014bebe9f 6. /build/src/Storages/AlterCommands.cpp:1533: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015c12c8c 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fcff4 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:32.264450 [ 6612 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt32)' because Variant type is not allowed. Set setting enable_variant_type = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:105: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014bec824 5. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014bebe9f 6. /build/src/Storages/AlterCommands.cpp:1533: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015c12c8c 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fcff4 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:32.420417 [ 6612 ] {f17980dd-076b-4751-830c-0a29152545f7} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Dynamic' because Dynamic type is not allowed. Set setting enable_dynamic_type = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57346) (comment: 03215_validate_type_in_alter_add_modify_column.sql) (query 12, line 14) (in query: alter table test modify column id Dynamic;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:149: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014bec8c0 5. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014bebe9f 6. /build/src/Storages/AlterCommands.cpp:1533: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015c12c8c 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fcff4 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:32.433006 [ 6612 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Dynamic' because Dynamic type is not allowed. Set setting enable_dynamic_type = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:149: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014bec8c0 5. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014bebe9f 6. /build/src/Storages/AlterCommands.cpp:1533: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015c12c8c 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fcff4 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:32.580778 [ 6612 ] {52110fbc-bf92-4876-9a40-61591a03bd1b} executeQuery: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt8) is prohibited by default due to expected negative impact on performance. It can be enabled with the `allow_suspicious_low_cardinality_types` setting. (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57346) (comment: 03215_validate_type_in_alter_add_modify_column.sql) (query 13, line 15) (in query: alter table test modify column id LowCardinality(UInt8);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:67: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014becaab 5. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014bebe9f 6. /build/src/Storages/AlterCommands.cpp:1533: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015c12c8c 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fcff4 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:32.591109 [ 6612 ] {} TCPHandler: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt8) is prohibited by default due to expected negative impact on performance. It can be enabled with the `allow_suspicious_low_cardinality_types` setting. (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:67: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014becaab 5. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014bebe9f 6. /build/src/Storages/AlterCommands.cpp:1533: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015c12c8c 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fcff4 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:32.820326 [ 6612 ] {d9f3d15b-bee1-4631-811b-f68760592c2e} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(10000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57346) (comment: 03215_validate_type_in_alter_add_modify_column.sql) (query 14, line 16) (in query: alter table test modify column id FixedString(10000);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000a309b0b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014bec95f 5. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014bebe9f 6. /build/src/Storages/AlterCommands.cpp:1533: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015c12c8c 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fcff4 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:32.840791 [ 6612 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(10000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000a309b0b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014bec95f 5. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014bebe9f 6. /build/src/Storages/AlterCommands.cpp:1533: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015c12c8c 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fcff4 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:32.912994 [ 27693 ] {a23513fb-ab2d-4188-b0e0-79ed966c1428} executeQuery: Code: 43. DB::Exception: Values for -Map cannot be summed, passed type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57364) (comment: 01621_summap_check_types.sql) (query 4, line 5) (in query: SELECT [NULL], sumMapWithOverflow(events, [NULL], [[(NULL)]], counts) FROM sum_map_overflow;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/AggregateFunctions/AggregateFunctionSumMap.cpp:130: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:se190107] (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*) @ 0x0000000010d83238 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130caa1d 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:17:32.920497 [ 27693 ] {} TCPHandler: Code: 43. DB::Exception: Values for -Map cannot be summed, passed type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/AggregateFunctions/AggregateFunctionSumMap.cpp:130: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:se190107] (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*) @ 0x0000000010d83238 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130caa1d 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:17:34.650374 [ 37313 ] {439904fa-6a25-4ba5-82b0-807d51572367} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57420) (comment: 00097_long_storage_buffer_race_condition_mt.sh) (query 2, line 1) (in query: DROP TABLE buf_00097;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/IStorage.cpp:171: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015c3ce9a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833683 6. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 7. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:34.677315 [ 37317 ] {94df2576-12c2-47cd-98b5-201b8ca4c70a} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57398) (comment: 00097_long_storage_buffer_race_condition_mt.sh) (query 2, line 1) (in query: DROP TABLE buf_00097;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/IStorage.cpp:171: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015c3ce9a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833683 6. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 7. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:34.737542 [ 37313 ] {} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/IStorage.cpp:171: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015c3ce9a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833683 6. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 7. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:34.821162 [ 37317 ] {} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/IStorage.cpp:171: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015c3ce9a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833683 6. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 7. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:34.831140 [ 37316 ] {ea7abcab-e960-48b5-8404-feb9293777c2} executeQuery: Code: 60. DB::Exception: Table test_1.buf_00097 does not exist. (UNKNOWN_TABLE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57410) (comment: 00097_long_storage_buffer_race_condition_mt.sh) (query 2, line 1) (in query: DROP TABLE buf_00097;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013cf9b5f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144148c9 6. /build/src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001441ae7d 7. /build/src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000148323f4 8. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 9. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 10. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:17:34.859928 [ 37316 ] {} TCPHandler: Code: 60. DB::Exception: Table test_1.buf_00097 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013cf9b5f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144148c9 6. /build/src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001441ae7d 7. /build/src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000148323f4 8. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 9. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 10. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:17:36.371703 [ 27693 ] {4b910e04-fee6-4f4f-85d8-1f9344d1c6b7} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57390) (comment: 00097_long_storage_buffer_race_condition_mt.sh) (query 10, line 5) (in query: DROP TABLE buf_00097;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/IStorage.cpp:171: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015c3ce9a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833683 6. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 7. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:36.434321 [ 27693 ] {} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/IStorage.cpp:171: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015c3ce9a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833683 6. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 7. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:36.999701 [ 40080 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:17:37.173835 [ 30862 ] {8b908751-b896-45a9-9249-807578f38172} executeQuery: Code: 207. DB::Exception: JOIN FULL OUTER JOIN ... ON t1.id = t2.id ambiguous identifier 'id'. In scope SELECT id FROM test_table_join_1 AS t1 FULL OUTER JOIN test_table_join_2 AS t2 ON t1.id = t2.id INNER JOIN test_table_join_3 AS t3 USING (id). (AMBIGUOUS_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34138) (comment: 02374_analyzer_join_using.gen.sql) (query 135, line 368) (in query: SELECT id FROM test_table_join_1 AS t1 FULL JOIN test_table_join_2 AS t2 ON t1.id = t2.id INNER JOIN test_table_join_3 AS t3 USING (id);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000013f6a64b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1013: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141df0fc 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141ddd52 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5226: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f6638e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 16. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:17:37.193840 [ 30862 ] {} TCPHandler: Code: 207. DB::Exception: JOIN FULL OUTER JOIN ... ON t1.id = t2.id ambiguous identifier 'id'. In scope SELECT id FROM test_table_join_1 AS t1 FULL OUTER JOIN test_table_join_2 AS t2 ON t1.id = t2.id INNER JOIN test_table_join_3 AS t3 USING (id). (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000013f6a64b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1013: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141df0fc 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141ddd52 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5226: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f6638e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 16. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:17:37.572130 [ 6612 ] {9cdec60d-1410-4844-afdf-782c33bdfa7c} 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]:57376) (comment: 00800_low_cardinality_merge_join.gen.sql) (query 13, line 15) (in query: SELECT * FROM (SELECT dummy AS val FROM system.one) s1 ANY LEFT JOIN (SELECT dummy AS val FROM system.one) s2 ON val + 0 = val * 1 ORDER BY val;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:562: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0ef83 5. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 6. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 7. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:17:37.584048 [ 6612 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:562: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0ef83 5. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 6. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 7. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:17:40.350966 [ 3772 ] {} DNSResolver: Cannot resolve host (localhos), error 0: Host not found. 2025.07.13 02:17:40.787760 [ 37316 ] {643f6568-b63e-49e1-a60d-352d73b7d9d9} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=873, jobs=850). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51302) (comment: 00662_has_nullable.sql) (query 12, line 21) (in query: -------------------------------------------------------------------------------- SELECT 'Nullable(UInt64), nullable array';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbdd1d3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd751c 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 9. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 10. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:17:40.804446 [ 37316 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=873, jobs=850). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbdd1d3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd751c 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 9. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 10. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:17:41.887593 [ 30862 ] {461ba6f9-b258-4a57-919b-fca7b7e06695} executeQuery: Code: 207. DB::Exception: JOIN FULL OUTER JOIN ... ON t1.id = t2.id ambiguous identifier 'id'. In scope SELECT id FROM test_table_join_1 AS t1 FULL OUTER JOIN test_table_join_2 AS t2 ON t1.id = t2.id LEFT JOIN test_table_join_3 AS t3 USING (id). (AMBIGUOUS_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34138) (comment: 02374_analyzer_join_using.gen.sql) (query 142, line 387) (in query: SELECT id FROM test_table_join_1 AS t1 FULL JOIN test_table_join_2 AS t2 ON t1.id = t2.id LEFT JOIN test_table_join_3 AS t3 USING (id);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000013f6a64b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1013: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141df0fc 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141ddd52 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5226: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f6638e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 16. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:17:41.906050 [ 30862 ] {} TCPHandler: Code: 207. DB::Exception: JOIN FULL OUTER JOIN ... ON t1.id = t2.id ambiguous identifier 'id'. In scope SELECT id FROM test_table_join_1 AS t1 FULL OUTER JOIN test_table_join_2 AS t2 ON t1.id = t2.id LEFT JOIN test_table_join_3 AS t3 USING (id). (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000013f6a64b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1013: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141df0fc 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141ddd52 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5226: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f6638e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 16. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:17:42.079238 [ 11496 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:17:43.846768 [ 4879 ] {0742b338-6f70-4298-8fec-0a6d4f267ee5} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 8 ($): $$ab . Expected one of: ALL, DISTINCT ON, DISTINCT, TOP, not empty list of expressions, list of expressions, list of elements, expression with optional alias, element of expression with optional alias, lambda expression, CAST operator, NOT, INTERVAL, CASE, DATE, TIMESTAMP, tuple, collection of literals, array, number, literal, NULL, NULL, Bool, TRUE, FALSE, string literal, asterisk, qualified asterisk, compound identifier, identifier, COLUMNS matcher, COLUMNS, qualified COLUMNS matcher, function name, substitution, MySQL-style global variable. (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:49052) (comment: 01949_heredoc_unfinished.sh) (in query: SELECT $$ab ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000009fd29ed 3. /build/src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9acc 4. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 5. /build/src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba32be 6. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 7. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 8. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 9. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:17:43.863746 [ 4879 ] {0742b338-6f70-4298-8fec-0a6d4f267ee5} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 8 ($): $$ab . Expected one of: ALL, DISTINCT ON, DISTINCT, TOP, not empty list of expressions, list of expressions, list of elements, expression with optional alias, element of expression with optional alias, lambda expression, CAST operator, NOT, INTERVAL, CASE, DATE, TIMESTAMP, tuple, collection of literals, array, number, literal, NULL, NULL, Bool, TRUE, FALSE, string literal, asterisk, qualified asterisk, compound identifier, identifier, COLUMNS matcher, COLUMNS, qualified COLUMNS matcher, function name, substitution, MySQL-style global variable. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000009fd29ed 3. /build/src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9acc 4. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 5. /build/src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba32be 6. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 7. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 8. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 9. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:17:44.125601 [ 3543 ] {9817078c-e6d8-4179-a337-c1b9a7c6fc25} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 5.74 MiB (attempt to allocate chunk of 1.93 MiB), maximum: 9.31 GiB: (avg_value_size_hint = 157.35579888957434, avg_chars_size = 179.2269586674892, limit = 6309): (while reading column query): (while reading from part /var/lib/clickhouse/store/e58/e5868042-e7c6-4840-b138-5ed55dc8d3ee/202507_1_80_11/ in table system.query_log (e5868042-e7c6-4840-b138-5ed55dc8d3ee) located on disk default of type local, from mark 0 with max_rows_to_read = 6309): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57422) (comment: 02477_s3_request_throttler.sh) (query 9, line 16) (in query: SELECT ProfileEvents['S3CreateMultipartUpload'] == 1, ProfileEvents['S3UploadPart'] == 1, ProfileEvents['S3CompleteMultipartUpload'] == 1 FROM system.query_log WHERE query LIKE '%request-throttler.csv%' AND type = 'QueryFinish' AND current_database = currentDatabase() ORDER BY query_start_time DESC LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x000000000fb2dd39 4. /build/src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2cb67 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2c5bf 6. /build/src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000fa9410c 7. /build/src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000000fa92864 8. /build/src/Common/PODArray.h:118: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000013c3922a 9. /build/src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000013ba04c3 10. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x00000000163ce98e 11. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000163ce0d2 12. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000163bc9b1 13. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000163c3d29 14. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x00000000163de7ba 15. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x00000000163dace0 16. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x0000000016d617ec 17. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5584 18. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 19. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 20. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 21. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 22. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 23. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 25. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:17:44.152746 [ 16757 ] {96ceee98-073e-4b28-87ce-d90022276642} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 8 ($): $$ . Expected one of: ALL, DISTINCT ON, DISTINCT, TOP, not empty list of expressions, list of expressions, list of elements, expression with optional alias, element of expression with optional alias, lambda expression, CAST operator, NOT, INTERVAL, CASE, DATE, TIMESTAMP, tuple, collection of literals, array, number, literal, NULL, NULL, Bool, TRUE, FALSE, string literal, asterisk, qualified asterisk, compound identifier, identifier, COLUMNS matcher, COLUMNS, qualified COLUMNS matcher, function name, substitution, MySQL-style global variable. (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:49064) (comment: 01949_heredoc_unfinished.sh) (in query: SELECT $$ ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000009fd29ed 3. /build/src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9acc 4. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 5. /build/src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba32be 6. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 7. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 8. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 9. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:17:44.179065 [ 3543 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 5.74 MiB (attempt to allocate chunk of 1.93 MiB), maximum: 9.31 GiB: (avg_value_size_hint = 157.35579888957434, avg_chars_size = 179.2269586674892, limit = 6309): (while reading column query): (while reading from part /var/lib/clickhouse/store/e58/e5868042-e7c6-4840-b138-5ed55dc8d3ee/202507_1_80_11/ in table system.query_log (e5868042-e7c6-4840-b138-5ed55dc8d3ee) located on disk default of type local, from mark 0 with max_rows_to_read = 6309): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x000000000fb2dd39 4. /build/src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2cb67 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2c5bf 6. /build/src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000fa9410c 7. /build/src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000000fa92864 8. /build/src/Common/PODArray.h:118: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000013c3922a 9. /build/src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000013ba04c3 10. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x00000000163ce98e 11. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000163ce0d2 12. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000163bc9b1 13. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000163c3d29 14. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x00000000163de7ba 15. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x00000000163dace0 16. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x0000000016d617ec 17. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5584 18. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 19. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 20. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 21. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 22. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 23. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 25. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:17:44.248531 [ 16757 ] {96ceee98-073e-4b28-87ce-d90022276642} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 8 ($): $$ . Expected one of: ALL, DISTINCT ON, DISTINCT, TOP, not empty list of expressions, list of expressions, list of elements, expression with optional alias, element of expression with optional alias, lambda expression, CAST operator, NOT, INTERVAL, CASE, DATE, TIMESTAMP, tuple, collection of literals, array, number, literal, NULL, NULL, Bool, TRUE, FALSE, string literal, asterisk, qualified asterisk, compound identifier, identifier, COLUMNS matcher, COLUMNS, qualified COLUMNS matcher, function name, substitution, MySQL-style global variable. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000009fd29ed 3. /build/src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9acc 4. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 5. /build/src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba32be 6. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 7. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 8. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 9. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:17:44.508889 [ 4887 ] {a2a5d9aa-25bf-41f1-a74f-b543f3c6e9b9} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 8 ($): $ . Expected one of: ALL, DISTINCT ON, DISTINCT, TOP, not empty list of expressions, list of expressions, list of elements, expression with optional alias, element of expression with optional alias, lambda expression, CAST operator, NOT, INTERVAL, CASE, DATE, TIMESTAMP, tuple, collection of literals, array, number, literal, NULL, NULL, Bool, TRUE, FALSE, string literal, asterisk, qualified asterisk, compound identifier, identifier, COLUMNS matcher, COLUMNS, qualified COLUMNS matcher, function name, substitution, MySQL-style global variable. (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:49072) (comment: 01949_heredoc_unfinished.sh) (in query: SELECT $ ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000009fd29ed 3. /build/src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9acc 4. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 5. /build/src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba32be 6. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 7. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 8. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 9. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:17:44.526956 [ 4887 ] {a2a5d9aa-25bf-41f1-a74f-b543f3c6e9b9} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 8 ($): $ . Expected one of: ALL, DISTINCT ON, DISTINCT, TOP, not empty list of expressions, list of expressions, list of elements, expression with optional alias, element of expression with optional alias, lambda expression, CAST operator, NOT, INTERVAL, CASE, DATE, TIMESTAMP, tuple, collection of literals, array, number, literal, NULL, NULL, Bool, TRUE, FALSE, string literal, asterisk, qualified asterisk, compound identifier, identifier, COLUMNS matcher, COLUMNS, qualified COLUMNS matcher, function name, substitution, MySQL-style global variable. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000009fd29ed 3. /build/src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9acc 4. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 5. /build/src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba32be 6. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 7. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 8. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 9. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:17:45.254230 [ 6612 ] {e7b7e28c-b2fa-458d-aa18-b56efe339c55} 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]:57376) (comment: 00800_low_cardinality_merge_join.gen.sql) (query 32, line 36) (in query: SELECT * FROM (SELECT dummy AS val FROM system.one) s1 ANY LEFT JOIN (SELECT dummy AS val FROM system.one) s2 USING val ORDER BY val;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Planner/PlannerJoins.cpp:1283: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x00000000148e4a3c 5. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0e7d2 6. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 7. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:17:45.275405 [ 6612 ] {} TCPHandler: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Planner/PlannerJoins.cpp:1283: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x00000000148e4a3c 5. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0e7d2 6. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 7. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:17:47.229870 [ 40065 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:17:48.720655 [ 16763 ] {6ef151fd-aa5d-4098-8c9b-43b3980ddbae} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=873, jobs=849). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51446) (comment: 02811_parallel_replicas_prewhere_count.sql) (query 7, line 9) (in query: SELECT count() FROM users PREWHERE uid > 2000;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbdd1d3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd751c 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 9. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 10. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:17:48.760390 [ 16763 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=873, jobs=849). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbdd1d3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd751c 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 9. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 10. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:17:48.870227 [ 30862 ] {b51c308d-8a58-4201-a5f1-54eff2a31967} executeQuery: Code: 207. DB::Exception: JOIN FULL OUTER JOIN ... ON t1.id = t2.id ambiguous identifier 'id'. In scope SELECT id FROM test_table_join_1 AS t1 FULL OUTER JOIN test_table_join_2 AS t2 ON t1.id = t2.id RIGHT JOIN test_table_join_3 AS t3 USING (id). (AMBIGUOUS_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34138) (comment: 02374_analyzer_join_using.gen.sql) (query 149, line 406) (in query: SELECT id FROM test_table_join_1 AS t1 FULL JOIN test_table_join_2 AS t2 ON t1.id = t2.id RIGHT JOIN test_table_join_3 AS t3 USING (id);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000013f6a64b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1013: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141df0fc 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141ddd52 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5226: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f6638e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 16. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:17:48.909740 [ 30862 ] {} TCPHandler: Code: 207. DB::Exception: JOIN FULL OUTER JOIN ... ON t1.id = t2.id ambiguous identifier 'id'. In scope SELECT id FROM test_table_join_1 AS t1 FULL OUTER JOIN test_table_join_2 AS t2 ON t1.id = t2.id RIGHT JOIN test_table_join_3 AS t3 USING (id). (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000013f6a64b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1013: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141df0fc 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141ddd52 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5226: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f6638e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 16. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:17:51.238105 [ 31788 ] {88e015a9-12c2-4ca1-84c6-c8659ac3827d} 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]:50788) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000013f6a64b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5272: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f672a9 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 9. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 14. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 15. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 16. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 17. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 22. ? @ 0x00007f7210eb6ac3 23. ? @ 0x00007f7210f48850 2025.07.13 02:17:51.245120 [ 31788 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000013f6a64b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5272: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f672a9 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 9. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 14. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 15. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 16. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 17. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 22. ? @ 0x00007f7210eb6ac3 23. ? @ 0x00007f7210f48850 2025.07.13 02:17:52.281994 [ 39957 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:17:54.189569 [ 5998 ] {bbae924c-6906-468e-a8d9-02eab22c5fd0} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 60057.541989 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:33484) (comment: 00284_external_aggregation_2.sql) (query 9, line 16) (in query: SELECT s, count() FROM t_00284_str GROUP BY s ORDER BY s LIMIT 10 OFFSET 42;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x0000000013ad84ab 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x0000000013ad77ec 5. /build/src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x000000001496af1f 6. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000168d1a5a 7. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0c24 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 2025.07.13 02:17:54.623183 [ 5998 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 60057.541989 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x0000000013ad84ab 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x0000000013ad77ec 5. /build/src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x000000001496af1f 6. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000168d1a5a 7. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0c24 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:17:55.361038 [ 6162 ] {77b93978-3d81-41e7-b79f-6aa6d6253bd0} 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.1]:9000 -> [::ffff:127.0.0.1]:53632). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fc62e75 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fc642b1 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x0000000009fb95be 5. /build/src/Server/TCPHandler.cpp:823: DB::TCPHandler::runImpl() @ 0x0000000016807266 6. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:17:56.062361 [ 16758 ] {5c16826d-d82a-4783-a49b-5d15961da226} 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]:50936) (comment: 00988_constraints_replication_zookeeper_long.sql) (query 3, line 6) (in query: CREATE TABLE replicated_constraints1 (`a` UInt32, `b` UInt32, CONSTRAINT a_constraint CHECK a < 10) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/test_00988/alter_constraints', 'r1') ORDER BY a SETTINGS index_granularity = 10612, min_bytes_for_wide_part = 794037879, 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 = 378626915, compact_parts_max_granules_to_buffer = 86, compact_parts_merge_max_bytes_to_prefetch_part = 6481061, merge_max_block_size = 20682, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 5627059590, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 9564616619, index_granularity_bytes = 9073405, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 24, 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 = 56959, primary_key_compress_block_size = 34011, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000013cc1696 5. /build/src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013cc32f5 6. /build/src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc384b 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:56.080673 [ 16758 ] {} TCPHandler: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000013cc1696 5. /build/src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013cc32f5 6. /build/src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc384b 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:17:57.324365 [ 30862 ] {51584701-0fab-4c48-87a2-c428bbef22c6} executeQuery: Code: 207. DB::Exception: JOIN FULL OUTER JOIN ... ON t1.id = t2.id ambiguous identifier 'id'. In scope SELECT id FROM test_table_join_1 AS t1 FULL OUTER JOIN test_table_join_2 AS t2 ON t1.id = t2.id FULL OUTER JOIN test_table_join_3 AS t3 USING (id). (AMBIGUOUS_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:34138) (comment: 02374_analyzer_join_using.gen.sql) (query 156, line 425) (in query: SELECT id FROM test_table_join_1 AS t1 FULL JOIN test_table_join_2 AS t2 ON t1.id = t2.id FULL JOIN test_table_join_3 AS t3 USING (id);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000013f6a64b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1013: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141df0fc 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141ddd52 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5226: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f6638e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 16. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:17:57.348873 [ 5077 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:17:57.363212 [ 30862 ] {} TCPHandler: Code: 207. DB::Exception: JOIN FULL OUTER JOIN ... ON t1.id = t2.id ambiguous identifier 'id'. In scope SELECT id FROM test_table_join_1 AS t1 FULL OUTER JOIN test_table_join_2 AS t2 ON t1.id = t2.id FULL OUTER JOIN test_table_join_3 AS t3 USING (id). (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000013f6a64b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1013: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141df0fc 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000141ddd52 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5226: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f6638e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 16. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:17:59.360225 [ 5121 ] {76f08757-82a2-43d8-9f37-9be7a21d56bd} executeQuery: Code: 57. DB::Exception: Table test_1.t already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36074) (comment: 01710_minmax_count_projection_distributed_query.sql) (query 2, line 2) (in query: CREATE TABLE t (`n` int, `s` String) ENGINE = MergeTree ORDER BY n SETTINGS index_granularity = 26549, 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 = 220663257, compact_parts_max_bytes_to_buffer = 183837170, compact_parts_max_granules_to_buffer = 101, compact_parts_merge_max_bytes_to_prefetch_part = 22220950, merge_max_block_size = 7644, old_parts_lifetime = 206., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 571943, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 27102206, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = true, enable_block_offset_column = false, cache_populated_by_fetch = true, marks_compress_block_size = 17503, primary_key_compress_block_size = 20678, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:17:59.419590 [ 5121 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:18:02.323031 [ 11007 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:18:03.385668 [ 4059 ] {} DNSResolver: Cannot resolve host (localhos), error 0: Host not found. 2025.07.13 02:18:06.443747 [ 4922 ] {e0675c36-7d82-4a84-a800-199f85a11d6c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=17, jobs=0): While reading or decompressing /var/lib/clickhouse/store/5cc/5ccf4b69-0e91-459b-b1aa-db2c8e826152/all_1_6_1/data.bin (position: 10354688, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 0134dc37cd6e1eaa782991ae7d68e6148289750000d8ea0000): (while reading column x): (while reading from part /var/lib/clickhouse/store/5cc/5ccf4b69-0e91-459b-b1aa-db2c8e826152/all_1_6_1/ in table test_w3syg2ri.tab (5ccf4b69-0e91-459b-b1aa-db2c8e826152) located on disk default of type local, from mark 343 with max_rows_to_read = 37575): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35558) (comment: 03286_parallel_replicas_cross_join_bug.sql) (query 6, line 8) (in query: select sum(x), sum(r.x) from (select * from tab l, tab r where r.x < 2 and l.x < 3);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x00000000130ebd1a 8. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:se190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x00000000130ebb0f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130eacce 10. /build/src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000130e21d0 11. /build/src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000130e24cb 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 13. /build/src/IO/ReadBuffer.h:96: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000fb79357 14. /build/src/Compression/CompressedReadBufferBase.cpp:209: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000017858d7c 15. /build/src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000001785bd1c 16. /build/src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000013bfcd1f 17. /build/src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000013ba04c3 18. /build/src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x00000000163b4199 19. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000163c87a0 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000163bc9b1 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000163c3d29 22. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x00000000163de7ba 23. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x00000000163dace0 24. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x0000000016d7ba8c 25. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5584 26. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 27. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 28. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 29. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 30. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 31. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 2025.07.13 02:18:06.523918 [ 4922 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=17, jobs=0): While reading or decompressing /var/lib/clickhouse/store/5cc/5ccf4b69-0e91-459b-b1aa-db2c8e826152/all_1_6_1/data.bin (position: 10354688, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 0134dc37cd6e1eaa782991ae7d68e6148289750000d8ea0000): (while reading column x): (while reading from part /var/lib/clickhouse/store/5cc/5ccf4b69-0e91-459b-b1aa-db2c8e826152/all_1_6_1/ in table test_w3syg2ri.tab (5ccf4b69-0e91-459b-b1aa-db2c8e826152) located on disk default of type local, from mark 343 with max_rows_to_read = 37575): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x00000000130ebd1a 8. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:se190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x00000000130ebb0f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130eacce 10. /build/src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000130e21d0 11. /build/src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000130e24cb 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 13. /build/src/IO/ReadBuffer.h:96: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000fb79357 14. /build/src/Compression/CompressedReadBufferBase.cpp:209: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000017858d7c 15. /build/src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000001785bd1c 16. /build/src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000013bfcd1f 17. /build/src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000013ba04c3 18. /build/src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x00000000163b4199 19. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000163c87a0 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000163bc9b1 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000163c3d29 22. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x00000000163de7ba 23. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x00000000163dace0 24. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x0000000016d7ba8c 25. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5584 26. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 27. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 28. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 29. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 30. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 31. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:18:06.712469 [ 37317 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778c58 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168167bf 10. /build/src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000001680ff45 11. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:18:06.718557 [ 37317 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x0000000016810069 5. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 6. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 2025.07.13 02:18:07.510680 [ 40080 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:18:07.716331 [ 6612 ] {3dfb6a13-0b8d-48cb-abc9-3ae335872c1d} executeQuery: Code: 403. DB::Exception: ASOF join does not support multiple inequality predicates in JOIN ON expression. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36082) (comment: 00976_asof_join_on.gen.sql) (query 21, line 27) (in query: SELECT A.a, A.t, B.b, B.t FROM A ASOF JOIN B ON A.a == B.b AND A.t < B.t AND A.t < B.t;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:605: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0ed0d 5. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 6. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 7. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:18:07.726980 [ 6612 ] {} TCPHandler: Code: 403. DB::Exception: ASOF join does not support multiple inequality predicates in JOIN ON expression. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:605: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0ed0d 5. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 6. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 7. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:18:08.288193 [ 6612 ] {e6affd36-aeec-435e-b0e8-9ab0731c0b63} executeQuery: Code: 403. DB::Exception: ASOF join requires one inequality predicate in JOIN ON expression, in [Predcates: (__table1.a = __table2.b, __table1.t = __table2.t)]. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36082) (comment: 00976_asof_join_on.gen.sql) (query 22, line 28) (in query: SELECT count() FROM A ASOF JOIN B ON A.a == B.b AND A.t == B.t;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:611: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0ef00 5. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 6. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 7. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:18:08.303591 [ 6612 ] {} TCPHandler: Code: 403. DB::Exception: ASOF join requires one inequality predicate in JOIN ON expression, in [Predcates: (__table1.a = __table2.b, __table1.t = __table2.t)]. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:611: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0ef00 5. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 6. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 7. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:18:08.515870 [ 6612 ] {fba8cc7e-d1d4-4aba-90fc-c47ad428b7ed} executeQuery: Code: 403. DB::Exception: ASOF join requires one inequality predicate in JOIN ON expression, in [Predcates: (__table1.a = __table2.b) Residual filter: ((notEquals(__table1.t, __table2.t)))]. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36082) (comment: 00976_asof_join_on.gen.sql) (query 23, line 29) (in query: SELECT count() FROM A ASOF JOIN B ON A.a == B.b AND A.t != B.t;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:611: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0ef00 5. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 6. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 7. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:18:08.527970 [ 6612 ] {} TCPHandler: Code: 403. DB::Exception: ASOF join requires one inequality predicate in JOIN ON expression, in [Predcates: (__table1.a = __table2.b) Residual filter: ((notEquals(__table1.t, __table2.t)))]. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:611: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0ef00 5. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 6. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 7. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:18:08.952055 [ 6612 ] {b38de4ee-e2b8-4bbe-af42-d41348692314} executeQuery: Code: 403. DB::Exception: ASOF join does not support multiple disjuncts in JOIN ON expression. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36082) (comment: 00976_asof_join_on.gen.sql) (query 24, line 31) (in query: SELECT A.a, A.t, B.b, B.t FROM A ASOF JOIN B ON A.a == B.b AND A.t < B.t OR A.a == B.b + 1 ORDER BY (A.a, A.t);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:591: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0ee45 5. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 6. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 7. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:18:09.002077 [ 6612 ] {} TCPHandler: Code: 403. DB::Exception: ASOF join does not support multiple disjuncts in JOIN ON expression. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:591: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0ee45 5. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 6. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 7. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:18:12.690016 [ 40079 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:18:14.416186 [ 6612 ] {ba686840-ff39-4c2d-bd7d-1ab50461c330} executeQuery: Code: 403. DB::Exception: ASOF join does not support multiple inequality predicates in JOIN ON expression. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36082) (comment: 00976_asof_join_on.gen.sql) (query 40, line 55) (in query: SELECT A.a, A.t, B.b, B.t FROM A ASOF JOIN B ON A.a == B.b AND A.t < B.t AND A.t < B.t;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:605: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0ed0d 5. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 6. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 7. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:18:14.433152 [ 6612 ] {} TCPHandler: Code: 403. DB::Exception: ASOF join does not support multiple inequality predicates in JOIN ON expression. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:605: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0ed0d 5. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 6. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 7. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:18:14.608683 [ 6612 ] {abd0167c-3080-486a-8f37-d9d05a1aa808} executeQuery: Code: 403. DB::Exception: ASOF join requires one inequality predicate in JOIN ON expression, in [Predcates: (__table1.a = __table2.b, __table1.t = __table2.t)]. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36082) (comment: 00976_asof_join_on.gen.sql) (query 41, line 56) (in query: SELECT count() FROM A ASOF JOIN B ON A.a == B.b AND A.t == B.t;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:611: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0ef00 5. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 6. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 7. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:18:14.620684 [ 6612 ] {} TCPHandler: Code: 403. DB::Exception: ASOF join requires one inequality predicate in JOIN ON expression, in [Predcates: (__table1.a = __table2.b, __table1.t = __table2.t)]. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:611: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0ef00 5. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 6. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 7. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:18:14.844491 [ 6612 ] {f910923e-142d-4f3e-9fe2-48ef7b8ad16e} executeQuery: Code: 403. DB::Exception: ASOF join requires one inequality predicate in JOIN ON expression, in [Predcates: (__table1.a = __table2.b) Residual filter: ((notEquals(__table1.t, __table2.t)))]. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36082) (comment: 00976_asof_join_on.gen.sql) (query 42, line 57) (in query: SELECT count() FROM A ASOF JOIN B ON A.a == B.b AND A.t != B.t;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:611: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0ef00 5. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 6. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 7. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:18:14.854568 [ 6612 ] {} TCPHandler: Code: 403. DB::Exception: ASOF join requires one inequality predicate in JOIN ON expression, in [Predcates: (__table1.a = __table2.b) Residual filter: ((notEquals(__table1.t, __table2.t)))]. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:611: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0ef00 5. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 6. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 7. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:18:15.296551 [ 6612 ] {b5ebda1a-e65c-4e1a-b318-6e7031f9f601} executeQuery: Code: 403. DB::Exception: ASOF join does not support multiple disjuncts in JOIN ON expression. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36082) (comment: 00976_asof_join_on.gen.sql) (query 43, line 59) (in query: SELECT A.a, A.t, B.b, B.t FROM A ASOF JOIN B ON A.a == B.b AND A.t < B.t OR A.a == B.b + 1 ORDER BY (A.a, A.t);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:591: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0ee45 5. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 6. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 7. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:18:15.303158 [ 6612 ] {} TCPHandler: Code: 403. DB::Exception: ASOF join does not support multiple disjuncts in JOIN ON expression. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:591: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0ee45 5. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 6. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 7. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:18:15.907629 [ 37313 ] {0c1e2477-a393-478f-8b1a-cfd4fc15de72} executeQuery: Code: 43. DB::Exception: Illegal type Array(Variant(Tuple(UInt8, UInt8))) expression, must be numeric type. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52598) (comment: 03203_variant_convert_field_to_type_bug.sql) (query 3, line 4) (in query: SELECT * FROM numbers([tuple(1, 2), NULL], 2);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/TableFunctions/TableFunctionNumbers.cpp:105: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x000000001170e12b 5. /build/src/TableFunctions/TableFunctionNumbers.cpp:79: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000001170d2af 6. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000130d4903 7. /build/src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000143537f2 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3da49 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:18:15.918423 [ 37313 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Variant(Tuple(UInt8, UInt8))) expression, must be numeric type. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/TableFunctions/TableFunctionNumbers.cpp:105: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x000000001170e12b 5. /build/src/TableFunctions/TableFunctionNumbers.cpp:79: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000001170d2af 6. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000130d4903 7. /build/src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000143537f2 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3da49 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:18:16.849976 [ 4888 ] {45b1df7f-657d-46d4-8a4e-af3e86a144da} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=29, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36234) (comment: 02210_processors_profile_log.sql) (query 4, line 6) (in query: WITH ( SELECT query_id FROM system.query_log WHERE current_database = currentDatabase() AND Settings['log_processors_profiles']='1' ) AS query_id_ SELECT name, multiIf( -- ExpressionTransform executes sleep(), -- so IProcessor::work() will spend 1 sec. -- We use two different timers to measure time: CLOCK_MONOTONIC for sleep and CLOCK_MONOTONIC_COARSE for profiling -- that's why we cannot compare directly with 1,000,000 microseconds - let's compare with 900,000 microseconds. name = 'ExpressionTransform', elapsed_us >= 0.9e6 ? 1 : elapsed_us, -- SourceFromSingleChunk, that feed data to ExpressionTransform, -- will feed first block and then wait in PortFull. name = 'SourceFromSingleChunk', output_wait_elapsed_us >= 0.9e6 ? 1 : output_wait_elapsed_us, -- LazyOutputFormatLazyOutputFormat is the output -- so it cannot starts to execute before sleep(1) will be executed. input_wait_elapsed_us>=1e6 ? 1 : input_wait_elapsed_us) elapsed, input_rows, input_bytes, output_rows, output_bytes FROM system.processors_profile_log WHERE query_id = query_id_ ORDER BY name;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x00000000163993d1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016396620 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001639641f 10. /build/src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000163b2bd7 11. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x00000000162ea22d 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x00000000162e6974 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x00000000163d9d66 14. /build/src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x0000000016d7885f 15. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x0000000016d9cdca 16. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5520 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 18. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 22. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 23. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:18:17.034691 [ 4888 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=29, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x00000000163993d1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016396620 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001639641f 10. /build/src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000163b2bd7 11. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x00000000162ea22d 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x00000000162e6974 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x00000000163d9d66 14. /build/src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x0000000016d7885f 15. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x0000000016d9cdca 16. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5520 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 18. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 22. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 23. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:631: DB::QueryAnalyzer::evaluateScalarSubqueryIfNeeded(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f3fbca 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3874: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38f19 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1247: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000013f47664 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000013f4856d 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f392f4 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3236a 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:18:17.591594 [ 5085 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:18:19.911067 [ 6612 ] {7652feb0-7ee4-47ac-906e-a123e93eb30f} executeQuery: Code: 403. DB::Exception: ASOF join does not support multiple inequality predicates in JOIN ON expression. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36082) (comment: 00976_asof_join_on.gen.sql) (query 59, line 83) (in query: SELECT A.a, A.t, B.b, B.t FROM A ASOF JOIN B ON A.a == B.b AND A.t < B.t AND A.t < B.t;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:605: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0ed0d 5. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 6. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 7. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:18:19.938631 [ 6612 ] {} TCPHandler: Code: 403. DB::Exception: ASOF join does not support multiple inequality predicates in JOIN ON expression. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:605: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0ed0d 5. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 6. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 7. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:18:20.214114 [ 6612 ] {436d3508-4d61-46db-a611-b8fe6ad105c0} executeQuery: Code: 403. DB::Exception: ASOF join requires one inequality predicate in JOIN ON expression, in [Predcates: (__table1.a = __table2.b, __table1.t = __table2.t)]. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36082) (comment: 00976_asof_join_on.gen.sql) (query 60, line 84) (in query: SELECT count() FROM A ASOF JOIN B ON A.a == B.b AND A.t == B.t;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:611: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0ef00 5. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 6. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 7. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:18:20.226684 [ 6612 ] {} TCPHandler: Code: 403. DB::Exception: ASOF join requires one inequality predicate in JOIN ON expression, in [Predcates: (__table1.a = __table2.b, __table1.t = __table2.t)]. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:611: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0ef00 5. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 6. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 7. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:18:20.412617 [ 6612 ] {e64d2eb1-d432-4d64-bba2-9b3e03f8653e} executeQuery: Code: 403. DB::Exception: ASOF join requires one inequality predicate in JOIN ON expression, in [Predcates: (__table1.a = __table2.b) Residual filter: ((notEquals(__table1.t, __table2.t)))]. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36082) (comment: 00976_asof_join_on.gen.sql) (query 61, line 85) (in query: SELECT count() FROM A ASOF JOIN B ON A.a == B.b AND A.t != B.t;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:611: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0ef00 5. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 6. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 7. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:18:20.426887 [ 5015 ] {22a7624f-c500-4adc-b7d2-f8ab202cc94c} 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]:53074) (comment: 03222_create_timeseries_table.sql) (in query: DROP DATABASE IF EXISTS test_5uwug0up SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:18:20.432006 [ 5015 ] {22a7624f-c500-4adc-b7d2-f8ab202cc94c} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:18:20.506232 [ 6612 ] {} TCPHandler: Code: 403. DB::Exception: ASOF join requires one inequality predicate in JOIN ON expression, in [Predcates: (__table1.a = __table2.b) Residual filter: ((notEquals(__table1.t, __table2.t)))]. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:611: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0ef00 5. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 6. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 7. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:18:20.690782 [ 6612 ] {0c9323f2-ad4d-43f9-ac7c-3375ab53e90e} executeQuery: Code: 403. DB::Exception: ASOF join does not support multiple disjuncts in JOIN ON expression. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36082) (comment: 00976_asof_join_on.gen.sql) (query 62, line 87) (in query: SELECT A.a, A.t, B.b, B.t FROM A ASOF JOIN B ON A.a == B.b AND A.t < B.t OR A.a == B.b + 1 ORDER BY (A.a, A.t);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:591: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0ee45 5. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 6. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 7. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:18:20.711690 [ 6612 ] {} TCPHandler: Code: 403. DB::Exception: ASOF join does not support multiple disjuncts in JOIN ON expression. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:591: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0ee45 5. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 6. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 7. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:18:20.906820 [ 16757 ] {1d2f7115-cfd3-47a0-b6cd-27002c8d6ca9} 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]:52224) (comment: 03222_create_timeseries_table.sql) (in query: DROP DATABASE IF EXISTS test_5uwug0up SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:18:20.915497 [ 16757 ] {1d2f7115-cfd3-47a0-b6cd-27002c8d6ca9} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:18:21.189627 [ 4887 ] {1448f6f0-4a7f-4d0d-876d-3465c95ab3df} executeQuery: Code: 433. DB::Exception: Delta codec argument must be unsigned integer. (ILLEGAL_CODEC_PARAMETER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38038) (comment: 01296_codecs_bad_arguments.sql) (query 4, line 5) (in query: CREATE TABLE delta_table (`id` UInt64 CODEC(Delta(tuple()))) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 49434, min_bytes_for_wide_part = 470151564, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 49, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 473614341, compact_parts_max_granules_to_buffer = 52, compact_parts_merge_max_bytes_to_prefetch_part = 30602876, merge_max_block_size = 623, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 9599273700, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 5164419634, index_granularity_bytes = 2565525, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 54718, primary_key_compress_block_size = 74495, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Compression/CompressionCodecDelta.cpp:207: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl[abi:se190107] (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x000000001786b808 5. /build/src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000001788beec 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013b9f869 7. /build/src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000013b9fb5d 8. /build/src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000001788ae8d 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000001480b791 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001480c764 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000001481759b 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:18:21.213193 [ 4887 ] {} TCPHandler: Code: 433. DB::Exception: Delta codec argument must be unsigned integer. (ILLEGAL_CODEC_PARAMETER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Compression/CompressionCodecDelta.cpp:207: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl[abi:se190107] (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x000000001786b808 5. /build/src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000001788beec 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013b9f869 7. /build/src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000013b9fb5d 8. /build/src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000001788ae8d 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000001480b791 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001480c764 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000001481759b 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:18:21.327799 [ 4930 ] {fc1efa43-d17c-481f-ad5e-a212264b571e} 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]:52238) (comment: 03222_create_timeseries_table.sql) (in query: DROP DATABASE IF EXISTS test_5uwug0up SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:18:21.335087 [ 4930 ] {fc1efa43-d17c-481f-ad5e-a212264b571e} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:18:21.391457 [ 4887 ] {4c3d6f24-8625-4cf7-b607-1867b9782c8e} executeQuery: Code: 433. DB::Exception: ZSTD codec argument must be integer. (ILLEGAL_CODEC_PARAMETER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38038) (comment: 01296_codecs_bad_arguments.sql) (query 5, line 6) (in query: CREATE TABLE zstd_table (`id` UInt64 CODEC(ZSTD(tuple()))) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 49434, min_bytes_for_wide_part = 470151564, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 49, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 473614341, compact_parts_max_granules_to_buffer = 52, compact_parts_merge_max_bytes_to_prefetch_part = 30602876, merge_max_block_size = 623, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 9599273700, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 5164419634, index_granularity_bytes = 2565525, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 54718, primary_key_compress_block_size = 74495, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Compression/CompressionCodecZSTD.cpp:99: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl[abi:se190107] (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x00000000178675b2 5. /build/src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000001788beec 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013b9f869 7. /build/src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000013b9fb5d 8. /build/src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000001788ae8d 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000001480b791 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001480c764 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000001481759b 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:18:21.404478 [ 4887 ] {} TCPHandler: Code: 433. DB::Exception: ZSTD codec argument must be integer. (ILLEGAL_CODEC_PARAMETER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Compression/CompressionCodecZSTD.cpp:99: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl[abi:se190107] (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x00000000178675b2 5. /build/src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000001788beec 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013b9f869 7. /build/src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000013b9fb5d 8. /build/src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000001788ae8d 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000001480b791 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001480c764 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000001481759b 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:18:21.639418 [ 4887 ] {c5890883-5935-459f-a4d4-deb9ffc657e2} executeQuery: Code: 433. DB::Exception: LZ4HC codec argument must be integer. (ILLEGAL_CODEC_PARAMETER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38038) (comment: 01296_codecs_bad_arguments.sql) (query 6, line 7) (in query: CREATE TABLE lz4_table (`id` UInt64 CODEC(LZ4HC(tuple()))) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 49434, min_bytes_for_wide_part = 470151564, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 49, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 473614341, compact_parts_max_granules_to_buffer = 52, compact_parts_merge_max_bytes_to_prefetch_part = 30602876, merge_max_block_size = 623, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 9599273700, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 5164419634, index_granularity_bytes = 2565525, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 54718, primary_key_compress_block_size = 74495, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Compression/CompressionCodecLZ4.cpp:134: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl[abi:se190107] (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x0000000017866631 5. /build/src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000001788beec 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013b9f869 7. /build/src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000013b9fb5d 8. /build/src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000001788ae8d 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000001480b791 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001480c764 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000001481759b 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:18:21.663343 [ 4887 ] {} TCPHandler: Code: 433. DB::Exception: LZ4HC codec argument must be integer. (ILLEGAL_CODEC_PARAMETER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Compression/CompressionCodecLZ4.cpp:134: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl[abi:se190107] (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x0000000017866631 5. /build/src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000001788beec 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013b9f869 7. /build/src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000013b9fb5d 8. /build/src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000001788ae8d 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000001480b791 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001480c764 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000001481759b 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:18:21.887180 [ 4887 ] {e952d409-904b-49c8-9765-9d69a906a8a4} executeQuery: Code: 378. DB::Exception: Compression codec LZ4 cannot have arguments. (DATA_TYPE_CANNOT_HAVE_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:38038) (comment: 01296_codecs_bad_arguments.sql) (query 7, line 9) (in query: CREATE TABLE lz4_table (`id` UInt64 CODEC(LZ4(tuple()))) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 49434, min_bytes_for_wide_part = 470151564, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 49, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 473614341, compact_parts_max_granules_to_buffer = 52, compact_parts_merge_max_bytes_to_prefetch_part = 30602876, merge_max_block_size = 623, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 9599273700, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 5164419634, index_granularity_bytes = 2565525, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 54718, primary_key_compress_block_size = 74495, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Compression/CompressionFactory.cpp:164: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl[abi:se190107], std::function ()>)::$_0, std::shared_ptr (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x0000000017863838 5. /build/src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000001788beec 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013b9f869 7. /build/src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000013b9fb5d 8. /build/src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000001788ae8d 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000001480b791 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001480c764 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000001481759b 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:18:21.912202 [ 4887 ] {} TCPHandler: Code: 378. DB::Exception: Compression codec LZ4 cannot have arguments. (DATA_TYPE_CANNOT_HAVE_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Compression/CompressionFactory.cpp:164: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl[abi:se190107], std::function ()>)::$_0, std::shared_ptr (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x0000000017863838 5. /build/src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000001788beec 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013b9f869 7. /build/src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000013b9fb5d 8. /build/src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000001788ae8d 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000001480b791 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001480c764 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000001481759b 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:18:22.626463 [ 5821 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:18:25.048629 [ 37317 ] {acc81306-a261-476e-847f-99468568f844} executeQuery: Code: 524. DB::Exception: ALTER of partition key column x from type Enum8('hello' = 1, 'world' = 2, 'goodbye' = 3) to type Enum8('hello' = 1, 'world' = 2) is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52562) (comment: 01346_alter_enum_partition_key_replicated_zookeeper_long.sql) (query 22, line 30) (in query: ALTER TABLE test MODIFY COLUMN x Enum('hello' = 1, 'world' = 2);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3820: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001625c818 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd033 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:18:25.066945 [ 37317 ] {} TCPHandler: Code: 524. DB::Exception: ALTER of partition key column x from type Enum8('hello' = 1, 'world' = 2, 'goodbye' = 3) to type Enum8('hello' = 1, 'world' = 2) is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3820: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001625c818 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd033 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:18:25.437739 [ 6612 ] {f5edf705-0eba-4bfe-89fe-fdfe12efaa2a} executeQuery: Code: 403. DB::Exception: ASOF join does not support multiple inequality predicates in JOIN ON expression. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36082) (comment: 00976_asof_join_on.gen.sql) (query 78, line 111) (in query: SELECT A.a, A.t, B.b, B.t FROM A ASOF JOIN B ON A.a == B.b AND A.t < B.t AND A.t < B.t;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:605: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0ed0d 5. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 6. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 7. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:18:25.447841 [ 6612 ] {} TCPHandler: Code: 403. DB::Exception: ASOF join does not support multiple inequality predicates in JOIN ON expression. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:605: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0ed0d 5. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 6. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 7. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:18:25.687827 [ 6612 ] {3b1f1651-e94c-4453-8d5a-d9fa0f2082bc} executeQuery: Code: 403. DB::Exception: ASOF join requires one inequality predicate in JOIN ON expression, in [Predcates: (__table1.a = __table2.b, __table1.t = __table2.t)]. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36082) (comment: 00976_asof_join_on.gen.sql) (query 79, line 112) (in query: SELECT count() FROM A ASOF JOIN B ON A.a == B.b AND A.t == B.t;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:611: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0ef00 5. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 6. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 7. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:18:25.703452 [ 6612 ] {} TCPHandler: Code: 403. DB::Exception: ASOF join requires one inequality predicate in JOIN ON expression, in [Predcates: (__table1.a = __table2.b, __table1.t = __table2.t)]. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:611: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0ef00 5. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 6. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 7. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:18:25.893255 [ 6612 ] {904ebd0d-27bd-4331-9df4-6e5ab39c0489} executeQuery: Code: 403. DB::Exception: ASOF join requires one inequality predicate in JOIN ON expression, in [Predcates: (__table1.a = __table2.b) Residual filter: ((notEquals(__table1.t, __table2.t)))]. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36082) (comment: 00976_asof_join_on.gen.sql) (query 80, line 113) (in query: SELECT count() FROM A ASOF JOIN B ON A.a == B.b AND A.t != B.t;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:611: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0ef00 5. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 6. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 7. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:18:25.912520 [ 6612 ] {} TCPHandler: Code: 403. DB::Exception: ASOF join requires one inequality predicate in JOIN ON expression, in [Predcates: (__table1.a = __table2.b) Residual filter: ((notEquals(__table1.t, __table2.t)))]. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:611: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0ef00 5. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 6. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 7. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:18:26.105129 [ 6612 ] {c9363315-42a1-4b5c-ad19-625558056f60} executeQuery: Code: 403. DB::Exception: ASOF join does not support multiple disjuncts in JOIN ON expression. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36082) (comment: 00976_asof_join_on.gen.sql) (query 81, line 115) (in query: SELECT A.a, A.t, B.b, B.t FROM A ASOF JOIN B ON A.a == B.b AND A.t < B.t OR A.a == B.b + 1 ORDER BY (A.a, A.t);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:591: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0ee45 5. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 6. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 7. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:18:26.131976 [ 6612 ] {} TCPHandler: Code: 403. DB::Exception: ASOF join does not support multiple disjuncts in JOIN ON expression. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:591: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0ee45 5. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 6. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 7. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:18:26.246084 [ 37317 ] {14b94080-dde4-43ef-85b2-859a17c1baa0} executeQuery: Code: 524. DB::Exception: ALTER of partition key column x from type Enum8('hello' = 1, 'world' = 2, 'test' = 3) to type Enum8('hello' = 1, 'world' = 2, 'goodbye' = 4) is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52562) (comment: 01346_alter_enum_partition_key_replicated_zookeeper_long.sql) (query 24, line 33) (in query: ALTER TABLE test MODIFY COLUMN x Enum('hello' = 1, 'world' = 2, 'goodbye' = 4);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3820: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001625c818 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd033 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:18:26.267001 [ 37317 ] {} TCPHandler: Code: 524. DB::Exception: ALTER of partition key column x from type Enum8('hello' = 1, 'world' = 2, 'test' = 3) to type Enum8('hello' = 1, 'world' = 2, 'goodbye' = 4) is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3820: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001625c818 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd033 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:18:26.416251 [ 3661 ] {} DNSResolver: Cannot resolve host (localhos), error 0: Host not found. 2025.07.13 02:18:27.631894 [ 5822 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:18:28.675070 [ 5128 ] {8e404c82-f4ee-4421-88d3-7442904e70cb} executeQuery: Code: 167. DB::Exception: AST is too deep. Maximum: 1000. (TOO_DEEP_AST) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:49154) (comment: 01196_max_parser_depth.sh) (in query: select coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, 1))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000b152a4b 4. /build/src/Parsers/IAST.cpp:162: DB::IAST::checkDepthImpl(unsigned long) const @ 0x00000000179586cf 5. /build/src/Parsers/IAST.h:99: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8aac 6. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 7. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 8. /build/src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba32be 9. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 10. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 11. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 12. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:18:28.748021 [ 5128 ] {8e404c82-f4ee-4421-88d3-7442904e70cb} DynamicQueryHandler: Code: 167. DB::Exception: AST is too deep. Maximum: 1000. (TOO_DEEP_AST), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000b152a4b 4. /build/src/Parsers/IAST.cpp:162: DB::IAST::checkDepthImpl(unsigned long) const @ 0x00000000179586cf 5. /build/src/Parsers/IAST.h:99: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000179b8aac 6. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9a66 7. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000179b9b5e 8. /build/src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba32be 9. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 10. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 11. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 12. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:18:30.193429 [ 6608 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000013779f8b 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000137794b8 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778bc3 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678d325 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:18:30.439172 [ 30862 ] {88e4a346-e852-497c-ae0e-3ba4e41e1e55} executeQuery: Code: 80. DB::Exception: Create table with statistics is now disabled. Turn on allow_experimental_statistics. (INCORRECT_QUERY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54970) (comment: 02864_statistics_ddl.sql) (query 4, line 11) (in query: -- Error case: Can't create statistics when allow_experimental_statistics = 0 CREATE TABLE tab (col Float64 STATISTICS(tdigest)) Engine = MergeTree() ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:713: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000001480bec1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001480c764 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000001481759b 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 10. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:18:30.454813 [ 30862 ] {} TCPHandler: Code: 80. DB::Exception: Create table with statistics is now disabled. Turn on allow_experimental_statistics. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:713: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000001480bec1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001480c764 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000001481759b 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 10. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:18:30.827343 [ 30862 ] {cefdaf3a-2352-4b5e-ad46-15e2e7f82f91} executeQuery: Code: 80. DB::Exception: Unknown statistics type: no_statistics_type. Supported statistics types are 'countmin', 'minmax', 'tdigest' and 'uniq'. (INCORRECT_QUERY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54970) (comment: 02864_statistics_ddl.sql) (query 6, line 16) (in query: -- Error case: Unknown statistics types are rejected CREATE TABLE tab (col Float64 STATISTICS(no_statistics_type)) Engine = MergeTree() ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/Storages/StatisticsDescription.cpp:54: DB::stringToStatisticsType(String) @ 0x0000000015c73fdb 5. /build/src/Storages/StatisticsDescription.cpp:177: DB::ColumnStatisticsDescription::fromColumnDeclaration(DB::ASTColumnDeclaration const&, std::shared_ptr) @ 0x0000000015c74e14 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:715: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000001480b82d 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001480c764 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000001481759b 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:18:30.858800 [ 30862 ] {} TCPHandler: Code: 80. DB::Exception: Unknown statistics type: no_statistics_type. Supported statistics types are 'countmin', 'minmax', 'tdigest' and 'uniq'. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/Storages/StatisticsDescription.cpp:54: DB::stringToStatisticsType(String) @ 0x0000000015c73fdb 5. /build/src/Storages/StatisticsDescription.cpp:177: DB::ColumnStatisticsDescription::fromColumnDeclaration(DB::ASTColumnDeclaration const&, std::shared_ptr) @ 0x0000000015c74e14 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:715: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000001480b82d 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001480c764 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000001481759b 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:18:31.161529 [ 30862 ] {6bfb21cc-ff0a-4e93-becd-5dceea45cf3c} executeQuery: Code: 80. DB::Exception: Column col already contains statistics type tdigest. (INCORRECT_QUERY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54970) (comment: 02864_statistics_ddl.sql) (query 7, line 19) (in query: -- Error case: The same statistics type can't exist more than once on a column CREATE TABLE tab (col Float64 STATISTICS(tdigest, tdigest)) Engine = MergeTree() ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000009fb598b 4. /build/src/Storages/StatisticsDescription.cpp:179: DB::ColumnStatisticsDescription::fromColumnDeclaration(DB::ASTColumnDeclaration const&, std::shared_ptr) @ 0x0000000015c74f59 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:715: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000001480b82d 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001480c764 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000001481759b 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:18:31.176815 [ 30862 ] {} TCPHandler: Code: 80. DB::Exception: Column col already contains statistics type tdigest. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000009fb598b 4. /build/src/Storages/StatisticsDescription.cpp:179: DB::ColumnStatisticsDescription::fromColumnDeclaration(DB::ASTColumnDeclaration const&, std::shared_ptr) @ 0x0000000015c74f59 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:715: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000001480b82d 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001480c764 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000001481759b 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:18:31.920947 [ 6608 ] {4518acf4-d26c-4b32-92e0-a210b9962c3e} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `test_11` in scope SELECT 'test_01194', test_11, 1. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:56200) (comment: 01194_http_query_id.sh) (in query: SELECT 'test_01194',test_11,1 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000013f69e39 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f3a889 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 16. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 17. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 18. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 19. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:18:31.927351 [ 6608 ] {4518acf4-d26c-4b32-92e0-a210b9962c3e} DynamicQueryHandler: Code: 47. DB::Exception: Unknown expression identifier `test_11` in scope SELECT 'test_01194', test_11, 1. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000013f69e39 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f3a889 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 16. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 17. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 18. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 19. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:18:32.046371 [ 31799 ] {a8dbdc12-b108-4304-8479-0da411e9552a} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `test_11` in scope SELECT 'test_01194', test_11, 2. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:56204) (comment: 01194_http_query_id.sh) (in query: SELECT 'test_01194',test_11,2 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000013f69e39 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f3a889 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 16. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 17. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 18. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 19. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:18:32.056585 [ 31799 ] {a8dbdc12-b108-4304-8479-0da411e9552a} DynamicQueryHandler: Code: 47. DB::Exception: Unknown expression identifier `test_11` in scope SELECT 'test_01194', test_11, 2. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000013f69e39 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f3a889 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 16. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 17. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 18. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 19. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:18:32.285382 [ 5877 ] {f7c62e18-8e28-483a-b26c-149351536999} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `test_11` in scope SELECT 'test_01194', test_11, 3. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:56220) (comment: 01194_http_query_id.sh) (in query: SELECT 'test_01194',test_11,3), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000013f69e39 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f3a889 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 16. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 17. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 18. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 19. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:18:32.315173 [ 5877 ] {f7c62e18-8e28-483a-b26c-149351536999} DynamicQueryHandler: Code: 47. DB::Exception: Unknown expression identifier `test_11` in scope SELECT 'test_01194', test_11, 3. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000013f69e39 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f3a889 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 16. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 17. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 18. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 19. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:18:32.506758 [ 6608 ] {d77651b2-907b-4add-b21d-e2e9e673c557} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `test_11` in scope SELECT 'test_01194', test_11, 4. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:56232) (comment: 01194_http_query_id.sh) (in query: SELECT 'test_01194',test_11,4), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000013f69e39 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f3a889 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 16. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 17. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 18. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 19. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:18:32.523481 [ 6608 ] {d77651b2-907b-4add-b21d-e2e9e673c557} DynamicQueryHandler: Code: 47. DB::Exception: Unknown expression identifier `test_11` in scope SELECT 'test_01194', test_11, 4. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000013f69e39 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f3a889 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 16. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 17. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 18. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 19. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:18:32.564896 [ 37317 ] {22de6e48-3aaf-4d67-98bd-181d1e60452f} executeQuery: Code: 524. DB::Exception: ALTER of partition key column x from type Int8 to type Enum8('' = 1) is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52562) (comment: 01346_alter_enum_partition_key_replicated_zookeeper_long.sql) (query 34, line 46) (in query: ALTER TABLE test MODIFY COLUMN x Enum8('' = 1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3820: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001625c818 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd033 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:18:32.583640 [ 37317 ] {} TCPHandler: Code: 524. DB::Exception: ALTER of partition key column x from type Int8 to type Enum8('' = 1) is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3820: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001625c818 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd033 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:18:32.768267 [ 39963 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:18:32.769530 [ 37317 ] {083677e9-902b-4612-a5df-a4f26a813cc6} executeQuery: Code: 524. DB::Exception: ALTER of partition key column x from type Int8 to type Enum16('' = 1) is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52562) (comment: 01346_alter_enum_partition_key_replicated_zookeeper_long.sql) (query 35, line 47) (in query: ALTER TABLE test MODIFY COLUMN x Enum16('' = 1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3820: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001625c818 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd033 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:18:32.818539 [ 37317 ] {} TCPHandler: Code: 524. DB::Exception: ALTER of partition key column x from type Int8 to type Enum16('' = 1) is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3820: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001625c818 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd033 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:18:32.956100 [ 37317 ] {37507557-9df2-46fc-bd8d-c4864ac32934} executeQuery: Code: 524. DB::Exception: ALTER of partition key column x from type Int8 to type UInt64 is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52562) (comment: 01346_alter_enum_partition_key_replicated_zookeeper_long.sql) (query 36, line 49) (in query: ALTER TABLE test MODIFY COLUMN x UInt64;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3820: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001625c818 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd033 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:18:32.984393 [ 37317 ] {} TCPHandler: Code: 524. DB::Exception: ALTER of partition key column x from type Int8 to type UInt64 is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3820: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001625c818 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd033 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:18:33.152651 [ 37317 ] {b3f0716f-88db-4c07-bf4d-ef51d36a6d7c} executeQuery: Code: 524. DB::Exception: ALTER of partition key column x from type Int8 to type String is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52562) (comment: 01346_alter_enum_partition_key_replicated_zookeeper_long.sql) (query 37, line 50) (in query: ALTER TABLE test MODIFY COLUMN x String;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3820: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001625c818 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd033 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:18:33.160926 [ 37317 ] {} TCPHandler: Code: 524. DB::Exception: ALTER of partition key column x from type Int8 to type String is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3820: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001625c818 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd033 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:18:33.256131 [ 31788 ] {81c228e3-bb80-4944-8595-9d0f8736ac90} 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]:54968) (comment: 02000_join_on_const.sql) (query 7, line 10) (in query: SELECT 70 = 10 * sum(t1.id) + sum(t2.id) AND count() == 4 FROM t1 JOIN t2 ON 1 = 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/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&) @ 0x00000000148d464b 5. /build/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&) @ 0x00000000148afcbb 6. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 7. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 9. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:18:33.264111 [ 37317 ] {f65f6fa2-6c17-4eb7-a333-158303f49460} executeQuery: Code: 524. DB::Exception: ALTER of partition key column x from type Int8 to type Nullable(Int64) is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52562) (comment: 01346_alter_enum_partition_key_replicated_zookeeper_long.sql) (query 38, line 51) (in query: ALTER TABLE test MODIFY COLUMN x Nullable(Int64);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3820: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001625c818 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd033 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:18:33.270315 [ 31788 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/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&) @ 0x00000000148d464b 5. /build/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&) @ 0x00000000148afcbb 6. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 7. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 9. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:18:33.276447 [ 37317 ] {} TCPHandler: Code: 524. DB::Exception: ALTER of partition key column x from type Int8 to type Nullable(Int64) is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a0458ab 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3820: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001625c818 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd033 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:18:33.585391 [ 37317 ] {9f45031a-3802-484d-9348-7979d8cc865d} executeQuery: Code: 524. DB::Exception: Trying to ALTER RENAME key x column which is a part of key expression. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52562) (comment: 01346_alter_enum_partition_key_replicated_zookeeper_long.sql) (query 39, line 53) (in query: ALTER TABLE test RENAME COLUMN x TO z;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3728: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001625bc7b 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd033 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:18:33.595399 [ 37317 ] {} TCPHandler: Code: 524. DB::Exception: Trying to ALTER RENAME key x column which is a part of key expression. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3728: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001625bc7b 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd033 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:18:33.705347 [ 37317 ] {2c87acb3-6287-4780-85f0-6baef7d3e8e7} executeQuery: Code: 524. DB::Exception: Trying to ALTER RENAME key y column which is a part of key expression. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52562) (comment: 01346_alter_enum_partition_key_replicated_zookeeper_long.sql) (query 40, line 54) (in query: ALTER TABLE test RENAME COLUMN y TO z;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3728: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001625bc7b 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd033 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:18:33.712284 [ 37317 ] {} TCPHandler: Code: 524. DB::Exception: Trying to ALTER RENAME key y column which is a part of key expression. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3728: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001625bc7b 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd033 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:18:33.862619 [ 37317 ] {8f1a1288-cf68-4bab-90ea-716161a1d28e} executeQuery: Code: 47. DB::Exception: Missing columns: 'x' while processing: 'x', required columns: 'x', available columns: 'y'. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52562) (comment: 01346_alter_enum_partition_key_replicated_zookeeper_long.sql) (query 41, line 55) (in query: ALTER TABLE test DROP COLUMN x;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Interpreters/TreeRewriter.cpp:1303: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x0000000014b1fec8 4. /build/src/Interpreters/TreeRewriter.cpp:1561: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x0000000014b28338 5. /build/src/Storages/KeyDescription.cpp:163: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x0000000015c4e955 6. /build/src/Storages/KeyDescription.cpp:78: DB::KeyDescription::recalculateWithNewAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x0000000015c4e0cf 7. /build/src/Storages/AlterCommands.cpp:1280: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000015c10f92 8. /build/src/Storages/MergeTree/MergeTreeData.cpp:3533: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001625916b 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd033 10. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:18:33.876087 [ 37317 ] {} TCPHandler: Code: 47. DB::Exception: Missing columns: 'x' while processing: 'x', required columns: 'x', available columns: 'y'. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Interpreters/TreeRewriter.cpp:1303: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x0000000014b1fec8 4. /build/src/Interpreters/TreeRewriter.cpp:1561: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x0000000014b28338 5. /build/src/Storages/KeyDescription.cpp:163: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x0000000015c4e955 6. /build/src/Storages/KeyDescription.cpp:78: DB::KeyDescription::recalculateWithNewAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x0000000015c4e0cf 7. /build/src/Storages/AlterCommands.cpp:1280: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000015c10f92 8. /build/src/Storages/MergeTree/MergeTreeData.cpp:3533: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001625916b 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd033 10. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:18:34.056974 [ 37317 ] {7816b626-3327-4be1-804e-260bb00fcec1} executeQuery: Code: 47. DB::Exception: Missing columns: 'y' while processing: 'y', required columns: 'y', available columns: 'x'. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52562) (comment: 01346_alter_enum_partition_key_replicated_zookeeper_long.sql) (query 42, line 56) (in query: ALTER TABLE test DROP COLUMN y;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Interpreters/TreeRewriter.cpp:1303: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x0000000014b1fec8 4. /build/src/Interpreters/TreeRewriter.cpp:1561: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x0000000014b28338 5. /build/src/Storages/KeyDescription.cpp:163: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x0000000015c4e955 6. /build/src/Storages/KeyDescription.cpp:78: DB::KeyDescription::recalculateWithNewAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x0000000015c4e0cf 7. /build/src/Storages/AlterCommands.cpp:1266: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000015c10f15 8. /build/src/Storages/MergeTree/MergeTreeData.cpp:3533: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001625916b 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd033 10. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:18:34.069941 [ 37317 ] {} TCPHandler: Code: 47. DB::Exception: Missing columns: 'y' while processing: 'y', required columns: 'y', available columns: 'x'. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Interpreters/TreeRewriter.cpp:1303: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x0000000014b1fec8 4. /build/src/Interpreters/TreeRewriter.cpp:1561: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x0000000014b28338 5. /build/src/Storages/KeyDescription.cpp:163: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x0000000015c4e955 6. /build/src/Storages/KeyDescription.cpp:78: DB::KeyDescription::recalculateWithNewAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x0000000015c4e0cf 7. /build/src/Storages/AlterCommands.cpp:1266: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000015c10f15 8. /build/src/Storages/MergeTree/MergeTreeData.cpp:3533: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001625916b 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd033 10. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:18:34.748539 [ 4547 ] {70602fbd-cac6-4dd3-912a-441ec86f5281} ExternalDictionariesLoader: Could not load external dictionary '02ea2b3a-7cb3-4b74-abb1-4f80305a92a9', next update is scheduled at 2025-07-13 02:18:39: Code: 482. DB::Exception: Dictionaries with executable dictionary source are not allowed to be created from DDL query. (DICTIONARY_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Dictionaries/ExecutableDictionarySource.cpp:233: std::shared_ptr std::__function::__policy_invoker (DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr, String const&, bool)>::__call_impl[abi:se190107] (DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr, String const&, bool)>>(std::__function::__policy_storage const*, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr&&, String const&, bool) @ 0x00000000119c8c6b 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012c76e33 6. /build/src/Dictionaries/DictionaryFactory.cpp:47: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x0000000012c74a2d 7. /build/src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000147cade4 8. /build/src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000147d6c48 9. /build/src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000147d56dd 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000147d96f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000147d64cd 5. /build/src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000147d465c 6. /build/src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x00000000147e47a8 7. /build/contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&) @ 0x00000000147e445c 8. /build/src/Interpreters/ExternalLoader.cpp:604: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000147d0b9f 9. /build/src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000147d0e15 10. /build/src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000147cb768 11. /build/src/Functions/FunctionsExternalDictionaries.h:76: DB::FunctionDictHelper::getDictionary(String const&) @ 0x000000000a11476c 12. /build/src/Functions/FunctionsExternalDictionaries.h:426: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a11185e 13. /build/src/Functions/FunctionsExternalDictionaries.h:831: DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a12d422 14. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 15. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 16. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 17. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 18. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 19. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 20. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 27. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 28. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 32. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 33. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 34. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 35. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 36. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 37. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 38. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 39. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 40. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 41. ? @ 0x00007f7210eb6ac3 42. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:18:34.755217 [ 6162 ] {70602fbd-cac6-4dd3-912a-441ec86f5281} executeQuery: Code: 482. DB::Exception: Dictionaries with executable dictionary source are not allowed to be created from DDL query: In scope SELECT dictGetString(concat('test_5', '.restricted_dict'), 'value', toUInt64(1)). (DICTIONARY_ACCESS_DENIED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54984) (comment: 01045_dictionaries_restrictions.sql) (query 2, line 11) (in query: SELECT dictGetString(concat('test_5', '.restricted_dict'), 'value', toUInt64(1))), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Dictionaries/ExecutableDictionarySource.cpp:233: std::shared_ptr std::__function::__policy_invoker (DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr, String const&, bool)>::__call_impl[abi:se190107] (DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr, String const&, bool)>>(std::__function::__policy_storage const*, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr&&, String const&, bool) @ 0x00000000119c8c6b 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012c76e33 6. /build/src/Dictionaries/DictionaryFactory.cpp:47: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x0000000012c74a2d 7. /build/src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000147cade4 8. /build/src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000147d6c48 9. /build/src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000147d56dd 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000147d96f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:18:34.762952 [ 6162 ] {} TCPHandler: Code: 482. DB::Exception: Dictionaries with executable dictionary source are not allowed to be created from DDL query: In scope SELECT dictGetString(concat('test_5', '.restricted_dict'), 'value', toUInt64(1)). (DICTIONARY_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Dictionaries/ExecutableDictionarySource.cpp:233: std::shared_ptr std::__function::__policy_invoker (DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr, String const&, bool)>::__call_impl[abi:se190107] (DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr, String const&, bool)>>(std::__function::__policy_storage const*, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr&&, String const&, bool) @ 0x00000000119c8c6b 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012c76e33 6. /build/src/Dictionaries/DictionaryFactory.cpp:47: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x0000000012c74a2d 7. /build/src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000147cade4 8. /build/src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000147d6c48 9. /build/src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000147d56dd 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000147d96f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000147d64cd 5. /build/src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000147d465c 6. /build/src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x00000000147e47a8 7. /build/contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&) @ 0x00000000147e445c 8. /build/src/Interpreters/ExternalLoader.cpp:604: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000147d0b9f 9. /build/src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000147d0e15 10. /build/src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000147cb768 11. /build/src/Functions/FunctionsExternalDictionaries.h:76: DB::FunctionDictHelper::getDictionary(String const&) @ 0x000000000a11476c 12. /build/src/Functions/FunctionsExternalDictionaries.h:426: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a11185e 13. /build/src/Functions/FunctionsExternalDictionaries.h:831: DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a12d422 14. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 15. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 16. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 17. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 18. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 19. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 20. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 27. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 28. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 32. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 33. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 34. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 35. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 36. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 37. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 38. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 39. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 40. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 41. ? @ 0x00007f7210eb6ac3 42. ? @ 0x00007f7210f48850 2025.07.13 02:18:35.709864 [ 6162 ] {b8487fa7-6963-4702-ba85-3f11aeb79c31} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 01045_dictionaries_restrictions.sql) (in query: /* ddl_entry=query-0000000134 */ TRUNCATE DICTIONARY IF EXISTS test_5.restricted_dict), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833ede 5. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 7. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 9. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 10. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 11. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 12. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 13. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 14. /build/src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833287 15. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 16. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 17. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 18. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:18:35.767388 [ 6162 ] {b8487fa7-6963-4702-ba85-3f11aeb79c31} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54984) (comment: 01045_dictionaries_restrictions.sql) (query 4, line 16) (in query: DROP DICTIONARY IF EXISTS test_5.restricted_dict), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833ede 5. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 7. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 9. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 10. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 11. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 12. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 13. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 14. /build/src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833287 15. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 16. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 17. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 18. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:18:35.799879 [ 6162 ] {} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833ede 5. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 7. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 9. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 10. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 11. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 12. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 13. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 14. /build/src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833287 15. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 16. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 17. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 18. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:18:37.377246 [ 37313 ] {8f3320aa-971b-4d6b-b8c6-e59bbed5a1ab} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=873, jobs=838). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:52624) (comment: 02155_binary_op_between_float_and_decimal.sql) (query 69, line 85) (in query: SELECT 'greatest';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbdd1d3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd751c 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 9. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 10. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:18:37.420730 [ 37313 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=873, jobs=838). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbdd1d3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd751c 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 9. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 10. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:18:37.952277 [ 39963 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:18:39.169192 [ 5128 ] {6096bb83-7e25-4eaa-8930-cc7a5ed79dd3} executeQuery: Code: 48. DB::Exception: MergeJoinAlgorithm does not implement ASOF Right join. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54978) (comment: 03149_asof_join_ddb_timestamps.sql) (query 15, line 66) (in query: SELECT p.begin, e.value FROM probe0 p ASOF RIGHT JOIN events0 e ON p.begin >= e.begin ORDER BY e.begin ASC;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::JoinKind&) @ 0x0000000016b4c50b 4. /build/src/Processors/Transforms/MergeJoinTransform.cpp:451: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(DB::JoinKind, DB::JoinStrictness, DB::TableJoin::JoinOnClause const&, std::vector> const&, unsigned long) @ 0x0000000016b44f97 5. /build/src/Processors/Transforms/MergeJoinTransform.cpp:470: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(std::shared_ptr, std::vector> const&, unsigned long) @ 0x0000000016b4532c 6. /build/src/Processors/Merges/IMergingTransform.h:112: DB::MergeJoinTransform::MergeJoinTransform(std::shared_ptr, std::vector> const&, DB::Block const&, unsigned long, unsigned long) @ 0x0000000016b4bab5 7. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::QueryPipelineBuilder::joinPipelinesYShaped(std::unique_ptr>, std::unique_ptr>, std::shared_ptr, DB::Block const&, unsigned long, std::vector, std::allocator>>*) @ 0x0000000013accc22 8. /build/src/Processors/QueryPlan/JoinStep.cpp:114: DB::JoinStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d01d35 9. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 14. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 15. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 20. ? @ 0x00007f7210eb6ac3 21. ? @ 0x00007f7210f48850 2025.07.13 02:18:39.172022 [ 30862 ] {5d5eba52-60ec-479b-8bc0-9b3276c2174c} executeQuery: Code: 57. DB::Exception: Table test_8t7sgxlv.tab already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02864_statistics_ddl.sql) (in query: /* ddl_entry=query-0000000011 */ CREATE TABLE test_8t7sgxlv.tab UUID 'f3472077-ea56-4256-85ae-86df3473745d' (`col` Date32 STATISTICS(tdigest)) ENGINE = MergeTree ORDER BY tuple()), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 12. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:18:39.174087 [ 5128 ] {} TCPHandler: Code: 48. DB::Exception: MergeJoinAlgorithm does not implement ASOF Right join. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::JoinKind&) @ 0x0000000016b4c50b 4. /build/src/Processors/Transforms/MergeJoinTransform.cpp:451: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(DB::JoinKind, DB::JoinStrictness, DB::TableJoin::JoinOnClause const&, std::vector> const&, unsigned long) @ 0x0000000016b44f97 5. /build/src/Processors/Transforms/MergeJoinTransform.cpp:470: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(std::shared_ptr, std::vector> const&, unsigned long) @ 0x0000000016b4532c 6. /build/src/Processors/Merges/IMergingTransform.h:112: DB::MergeJoinTransform::MergeJoinTransform(std::shared_ptr, std::vector> const&, DB::Block const&, unsigned long, unsigned long) @ 0x0000000016b4bab5 7. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::QueryPipelineBuilder::joinPipelinesYShaped(std::unique_ptr>, std::unique_ptr>, std::shared_ptr, DB::Block const&, unsigned long, std::vector, std::allocator>>*) @ 0x0000000013accc22 8. /build/src/Processors/QueryPlan/JoinStep.cpp:114: DB::JoinStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d01d35 9. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 14. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 15. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 20. ? @ 0x00007f7210eb6ac3 21. ? @ 0x00007f7210f48850 2025.07.13 02:18:39.198513 [ 30862 ] {5d5eba52-60ec-479b-8bc0-9b3276c2174c} executeQuery: Code: 57. DB::Exception: Table test_8t7sgxlv.tab already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54970) (comment: 02864_statistics_ddl.sql) (query 19, line 33) (in query: CREATE TABLE tab (col Date32 STATISTICS(tdigest)) Engine = MergeTree() ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 12. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:18:39.204397 [ 30862 ] {} TCPHandler: Code: 57. DB::Exception: Table test_8t7sgxlv.tab already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 12. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:18:39.258435 [ 5128 ] {bf40af41-1e56-4a92-bd82-2430b7743783} 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]:54978) (comment: 03149_asof_join_ddb_timestamps.sql) (query 16, line 74) (in query: SELECT p.begin, e.value FROM probe0 p ASOF RIGHT JOIN events0 e USING (begin) ORDER BY e.begin ASC;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Planner/PlannerJoins.cpp:1283: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x00000000148e4a3c 5. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0e7d2 6. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 7. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:18:39.270960 [ 5128 ] {} TCPHandler: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Planner/PlannerJoins.cpp:1283: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x00000000148e4a3c 5. /build/src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x0000000016d0e7d2 6. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000016dda5de 7. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1ad0 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:18:39.331112 [ 3543 ] {6643964f-218e-4a0f-887d-d03773e6c833} 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]:53416) (comment: 02864_statistics_ddl.sql) (in query: DROP DATABASE IF EXISTS test_8t7sgxlv SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:18:39.334367 [ 3543 ] {6643964f-218e-4a0f-887d-d03773e6c833} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:18:40.052811 [ 30811 ] {08b75f4b-4f2f-4c64-99e9-9ccfc8892beb} 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]:48140) (comment: 02441_alter_delete_and_drop_column.sql) (query 1, line 4) (in query: CREATE TABLE mut (`n` int, `m` int, `k` int) ENGINE = ReplicatedMergeTree('/test/02441/{database}/mut', '1') ORDER BY n SETTINGS index_granularity = 50735, min_bytes_for_wide_part = 592982116, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 32, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 503046382, compact_parts_max_granules_to_buffer = 7, compact_parts_merge_max_bytes_to_prefetch_part = 10796409, merge_max_block_size = 7361, 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 = 100, min_merge_bytes_to_use_direct_io = 5592734053, index_granularity_bytes = 6304496, 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 = 44564, primary_key_compress_block_size = 59013, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000013cc1696 5. /build/src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013cc32f5 6. /build/src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc384b 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:18:40.089327 [ 30811 ] {} TCPHandler: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000013cc1696 5. /build/src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013cc32f5 6. /build/src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc384b 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:18:42.566121 [ 3543 ] {88bc103e-cb95-4d38-a80b-173c2b65c0c0} executeQuery: Code: 48. DB::Exception: WITH TOTALS, ROLLUP, CUBE or GROUPING SETS are not supported without aggregation. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48174) (comment: 01013_totals_without_aggregation.sql) (query 5, line 6) (in query: SELECT 1 AS n WITH TOTALS;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Analyzer/ValidationUtils.cpp:366: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000013f864d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f332a5 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:18:42.577236 [ 3543 ] {} TCPHandler: Code: 48. DB::Exception: WITH TOTALS, ROLLUP, CUBE or GROUPING SETS are not supported without aggregation. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Analyzer/ValidationUtils.cpp:366: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000013f864d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f332a5 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:18:42.716509 [ 3543 ] {bfda184b-0a80-414e-a569-9b3dfee61a2f} executeQuery: Code: 48. DB::Exception: WITH TOTALS, ROLLUP, CUBE or GROUPING SETS are not supported without aggregation. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48174) (comment: 01013_totals_without_aggregation.sql) (query 6, line 7) (in query: SELECT 1 AS n WITH ROLLUP;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Analyzer/ValidationUtils.cpp:366: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000013f864d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f332a5 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:18:42.722342 [ 3543 ] {} TCPHandler: Code: 48. DB::Exception: WITH TOTALS, ROLLUP, CUBE or GROUPING SETS are not supported without aggregation. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Analyzer/ValidationUtils.cpp:366: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000013f864d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f332a5 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:18:42.813800 [ 3543 ] {c3c810ec-0ca2-4ecd-b281-5acfd9975cc7} executeQuery: Code: 48. DB::Exception: WITH TOTALS, ROLLUP, CUBE or GROUPING SETS are not supported without aggregation. (NOT_IMPLEMENTED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48174) (comment: 01013_totals_without_aggregation.sql) (query 7, line 8) (in query: SELECT 1 AS n WITH CUBE;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Analyzer/ValidationUtils.cpp:366: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000013f864d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f332a5 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:18:42.822037 [ 3543 ] {} TCPHandler: Code: 48. DB::Exception: WITH TOTALS, ROLLUP, CUBE or GROUPING SETS are not supported without aggregation. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Analyzer/ValidationUtils.cpp:366: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000013f864d6 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f332a5 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:18:42.858428 [ 6162 ] {856037f9-dbb4-49eb-bc0d-bfc1c8be49c0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=873, jobs=834). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54990) (comment: 03272_json_to_json_alter.gen.sql) (query 24, line 34) (in query: select json.k0, json.k1, json.k2, json.k3, json.k4, json.k5, json.k6, json.k7, json.k8, json.k9 from test;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbdd1d3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd751c 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 9. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 10. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:18:42.862672 [ 39724 ] {} ExternalDictionariesLoader: Could not load external dictionary '02ea2b3a-7cb3-4b74-abb1-4f80305a92a9', next update is scheduled at 2025-07-13 02:18:47: Code: 482. DB::Exception: Dictionaries with executable dictionary source are not allowed to be created from DDL query. (DICTIONARY_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Dictionaries/ExecutableDictionarySource.cpp:233: std::shared_ptr std::__function::__policy_invoker (DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr, String const&, bool)>::__call_impl[abi:se190107] (DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr, String const&, bool)>>(std::__function::__policy_storage const*, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr&&, String const&, bool) @ 0x00000000119c8c6b 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012c76e33 6. /build/src/Dictionaries/DictionaryFactory.cpp:47: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x0000000012c74a2d 7. /build/src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000147cade4 8. /build/src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000147d6c48 9. /build/src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000147d56dd 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000147d96f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:18:42.888645 [ 6162 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=873, jobs=834). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbdd1d3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd751c 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 9. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 10. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:18:43.195195 [ 5077 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:18:44.773107 [ 30811 ] {19d6cec1-ed7b-4008-9d78-f2ae72f58720} 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]:48168) (comment: 01669_columns_declaration_serde_long.sql) (query 13, line 26) (in query: CREATE TABLE test_r1 (`x` UInt64, `\\` String DEFAULT concat('\r\n\t\\', '\n')) ENGINE = ReplicatedMergeTree('/clickhouse/{database}/test_01669', 'r1') ORDER BY `\\` SETTINGS index_granularity = 37674, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.6319321990013123, replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 340332670, compact_parts_max_bytes_to_buffer = 481303723, compact_parts_max_granules_to_buffer = 211, compact_parts_merge_max_bytes_to_prefetch_part = 22280455, merge_max_block_size = 7391, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 9050102211, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 7959455438, index_granularity_bytes = 18210086, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 78, 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 = 59533, primary_key_compress_block_size = 44668, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000013cc1696 5. /build/src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013cc32f5 6. /build/src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc384b 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:18:44.809736 [ 30811 ] {} TCPHandler: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000013cc1696 5. /build/src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013cc32f5 6. /build/src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc384b 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:18:46.030898 [ 4888 ] {a24d9912-80a8-4b75-b809-65ba7d4ebeb4} 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]:48252) (comment: 00423_storage_log_single_thread.sql) (query 5, line 7) (in query: DETACH TABLE log;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Databases/DatabaseReplicated.cpp:1106: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013cc3688 5. /build/src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc384b 6. /build/src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833287 7. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 8. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 9. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:18:46.055460 [ 4922 ] {e81fe53a-6c59-404c-8067-3dea09c7ea0e} executeQuery: Code: 36. DB::Exception: Function icebergTruncate accepts only positive width: In scope SELECT icebergTruncate(0, 55). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:55030) (comment: 03376_iceberg_truncate.sql) (query 37, line 45) (in query: SELECT icebergTruncate(0, 55);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/icebergTruncate.cpp:121: DB::(anonymous namespace)::FunctionIcebergTruncate::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c16ed59 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:18:46.055742 [ 4888 ] {} TCPHandler: Code: 80. DB::Exception: DETACH TABLE is not allowed for Replicated databases. Use DETACH TABLE PERMANENTLY or SYSTEM RESTART REPLICA or set database_replicated_always_detach_permanently to 1. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Databases/DatabaseReplicated.cpp:1106: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013cc3688 5. /build/src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc384b 6. /build/src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833287 7. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 8. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 9. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:18:46.068772 [ 4922 ] {} TCPHandler: Code: 36. DB::Exception: Function icebergTruncate accepts only positive width: In scope SELECT icebergTruncate(0, 55). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/icebergTruncate.cpp:121: DB::(anonymous namespace)::FunctionIcebergTruncate::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c16ed59 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 26. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 27. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 2025.07.13 02:18:46.178019 [ 4922 ] {6b9af2bb-2017-47b6-8cdb-5faed9a589ca} executeQuery: Code: 43. DB::Exception: First argument should be UInt data type: In scope SELECT icebergTruncate(-1, 55). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:55030) (comment: 03376_iceberg_truncate.sql) (query 38, line 46) (in query: SELECT icebergTruncate(-1, 55);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/icebergTruncate.cpp:73: DB::(anonymous namespace)::FunctionIcebergTruncate::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000c1700a5 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:18:46.196039 [ 4922 ] {} TCPHandler: Code: 43. DB::Exception: First argument should be UInt data type: In scope SELECT icebergTruncate(-1, 55). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/icebergTruncate.cpp:73: DB::(anonymous namespace)::FunctionIcebergTruncate::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000c1700a5 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:18:46.493082 [ 4922 ] {01c2647a-6ef3-4819-9e58-da9581368e0d} executeQuery: Code: 43. DB::Exception: Second argument must be of native integer type, String/FixedString, Decimal: In scope SELECT icebergTruncate(3, 0.). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:55030) (comment: 03376_iceberg_truncate.sql) (query 39, line 47) (in query: SELECT icebergTruncate(3, 0.0);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/icebergTruncate.cpp:78: DB::(anonymous namespace)::FunctionIcebergTruncate::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000c170123 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:18:46.500670 [ 4922 ] {} TCPHandler: Code: 43. DB::Exception: Second argument must be of native integer type, String/FixedString, Decimal: In scope SELECT icebergTruncate(3, 0.). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/icebergTruncate.cpp:78: DB::(anonymous namespace)::FunctionIcebergTruncate::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000c170123 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:18:47.852963 [ 3543 ] {7a11493a-626a-4c40-ac82-341b5fb0cec2} 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]:48226) (comment: 01272_totals_and_filter_bug.sql) (query 7, line 11) (in query: SELECT dimension_1, sum_metric_1, sum_metric_2 FROM ( SELECT dimension_1, sum(metric_1) AS sum_metric_1 FROM foo GROUP BY dimension_1 WITH TOTALS ) AS subquery_1 ALL FULL OUTER JOIN ( SELECT dimension_1, sum(metric_2) AS sum_metric_2 FROM bar GROUP BY dimension_1 WITH TOTALS ) AS subquery_2 USING (dimension_1) WHERE sum_metric_2 < 20 ORDER BY dimension_1 ASC;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/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>>*) @ 0x0000000013accdac 5. /build/src/Processors/QueryPlan/JoinStep.cpp:114: DB::JoinStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d01d35 6. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 7. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:18:47.889246 [ 3543 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/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>>*) @ 0x0000000013accdac 5. /build/src/Processors/QueryPlan/JoinStep.cpp:114: DB::JoinStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d01d35 6. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 7. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:18:47.996740 [ 10910 ] {} ExternalDictionariesLoader: Could not load external dictionary '02ea2b3a-7cb3-4b74-abb1-4f80305a92a9', next update is scheduled at 2025-07-13 02:18:56: Code: 482. DB::Exception: Dictionaries with executable dictionary source are not allowed to be created from DDL query. (DICTIONARY_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Dictionaries/ExecutableDictionarySource.cpp:233: std::shared_ptr std::__function::__policy_invoker (DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr, String const&, bool)>::__call_impl[abi:se190107] (DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr, String const&, bool)>>(std::__function::__policy_storage const*, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr&&, String const&, bool) @ 0x00000000119c8c6b 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012c76e33 6. /build/src/Dictionaries/DictionaryFactory.cpp:47: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x0000000012c74a2d 7. /build/src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000147cade4 8. /build/src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000147d6c48 9. /build/src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000147d56dd 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000147d96f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:18:48.147180 [ 11489 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:18:49.217423 [ 6612 ] {3c87ad8d-de52-4ce6-8f55-5ec7ac90fe90} executeQuery: Code: 57. DB::Exception: Table test_5.foo already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02680_mysql_ast_logical_err.sql) (in query: /* ddl_entry=query-0000000140 */ CREATE TABLE test_5.foo UUID '6bd898b4-c9d9-46c0-9cc4-147744d4d037' (`key` UInt32, `a` String, `b` Int64, `c` String) ENGINE = TinyLog), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 12. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:18:49.321654 [ 6612 ] {3c87ad8d-de52-4ce6-8f55-5ec7ac90fe90} executeQuery: Code: 57. DB::Exception: Table test_5.foo already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:48324) (comment: 02680_mysql_ast_logical_err.sql) (query 1, line 1) (in query: CREATE TABLE foo (key UInt32, a String, b Int64, c String) ENGINE = TinyLog;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 12. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:18:49.341456 [ 6612 ] {} TCPHandler: Code: 57. DB::Exception: Table test_5.foo already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 12. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:18:49.440613 [ 3928 ] {} DNSResolver: Cannot resolve host (localhos), error 0: Host not found. 2025.07.13 02:18:53.320791 [ 11489 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:18:53.405557 [ 37319 ] {} InterserverIOHTTPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=17, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x00000000130ebd1a 8. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:se190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x00000000130ebb0f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130eacce 10. /build/src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000130e21d0 11. /build/src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000130e24cb 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 13. /build/src/IO/ReadBuffer.h:96: DB::(anonymous namespace)::copyDataImpl(DB::ReadBuffer&, DB::WriteBuffer&, bool, unsigned long, std::function, std::shared_ptr) @ 0x000000000fba1187 14. /build/src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000000fba16a6 15. /build/src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x0000000016132189 16. /build/src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x0000000016130911 17. /build/src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x00000000167a1e5f 18. /build/src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167a248e 19. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:18:53.728105 [ 4286 ] {} test_7.mutations_and_quorum2 (c558d140-1827-4f66-8e07-3c27e2a82bd9): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::IOException::IOException(String const&, int) @ 0x000000001aaee572 1. /build/base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x000000001ab75109 2. /build/base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x000000001ab502cc 3. /build/base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000001ab505b3 4. /build/src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000001174cf1b 5. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001174a33d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001174592b 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000117492ab 9. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 10. /build/src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000011747352 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000001173ed20 12. /build/src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000161362ae 13. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015eba47e 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015df873d 15. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015de95eb 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015dda45b 17. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015eb81fe 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000164fb1a3 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015e1bcca 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000161700b2 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001621dad0 22. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001621e3ba 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:18:58.184615 [ 12973 ] {} ExternalDictionariesLoader: Could not load external dictionary '02ea2b3a-7cb3-4b74-abb1-4f80305a92a9', next update is scheduled at 2025-07-13 02:19:05: Code: 482. DB::Exception: Dictionaries with executable dictionary source are not allowed to be created from DDL query. (DICTIONARY_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Dictionaries/ExecutableDictionarySource.cpp:233: std::shared_ptr std::__function::__policy_invoker (DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr, String const&, bool)>::__call_impl[abi:se190107] (DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr, String const&, bool)>>(std::__function::__policy_storage const*, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr&&, String const&, bool) @ 0x00000000119c8c6b 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012c76e33 6. /build/src/Dictionaries/DictionaryFactory.cpp:47: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x0000000012c74a2d 7. /build/src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000147cade4 8. /build/src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000147d6c48 9. /build/src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000147d56dd 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000147d96f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:18:58.481917 [ 39963 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:18:58.781404 [ 37313 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778c58 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168167bf 10. /build/src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000001680ff45 11. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:18:58.795294 [ 37313 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x0000000016810069 5. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 6. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 2025.07.13 02:19:01.752672 [ 27539 ] {5d4a3da9-29fb-4ac1-afcc-d123214a77e2} executeQuery: Code: 469. DB::Exception: Constraint `cs_value2` for table test_9i6l1yio.table_for_rename (2ff6d713-a665-4f60-a5f5-0fb915f78930) is violated at row 1. Expression: (toInt64(value2) < toInt64(value3)). Column values: value2 = '1', value3 = '0'. (VIOLATED_CONSTRAINT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36734) (comment: 01277_alter_rename_column_constraint.sql) (query 4, line 18) (in query: INSERT INTO table_for_rename SELECT toDate('2019-10-01') + number % 3, number, toString(number), toString(number + 1), toString(number) from numbers(9);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&) @ 0x0000000013bf7039 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000016b2113c 5. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 7. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 10. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 11. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 12. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 13. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168cfe81 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:19:01.763598 [ 27539 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `cs_value2` for table test_9i6l1yio.table_for_rename (2ff6d713-a665-4f60-a5f5-0fb915f78930) is violated at row 1. Expression: (toInt64(value2) < toInt64(value3)). Column values: value2 = '1', value3 = '0'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&) @ 0x0000000013bf7039 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000016b2113c 5. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 7. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 10. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 11. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 12. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 13. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168cfe81 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x00000000168cf907 5. /build/src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000001680710e 6. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 2025.07.13 02:19:02.773732 [ 37317 ] {7d671a34-4c53-49d1-8612-fe1101c9060d} 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]:36826) (comment: 01319_manual_write_to_replicas_long.sql) (query 3, line 7) (in query: CREATE TABLE r1 (`x` String) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/r', 'r1') ORDER BY x SETTINGS index_granularity = 57415, min_bytes_for_wide_part = 311820958, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 27, min_bytes_for_full_part_storage = 177372928, compact_parts_max_bytes_to_buffer = 433671353, compact_parts_max_granules_to_buffer = 42, compact_parts_merge_max_bytes_to_prefetch_part = 11294921, merge_max_block_size = 1389, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 7116774171, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 4102304576, index_granularity_bytes = 13101493, 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 = false, cache_populated_by_fetch = false, marks_compress_block_size = 60396, primary_key_compress_block_size = 22069, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000013cc1696 5. /build/src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013cc32f5 6. /build/src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc384b 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:19:02.791378 [ 37317 ] {} TCPHandler: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000013cc1696 5. /build/src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013cc32f5 6. /build/src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc384b 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:19:03.482690 [ 12992 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:19:04.172248 [ 12992 ] {} ExternalDictionariesLoader: Could not update external dictionary 'd6fbfd16-05c4-4288-b325-142078f64329', leaving the previous version, next update is scheduled at 2025-07-13 02:19:10: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=17, jobs=0): While reading or decompressing /var/lib/clickhouse/store/abc/abc18f76-edc8-4dc8-8cbd-24181e16ad46/20221021_2_2_0/data.bin (position: 56, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: eebd31d14d95363dddb92967eb596636820c00000002000000): (while reading column val): (while reading from part /var/lib/clickhouse/store/abc/abc18f76-edc8-4dc8-8cbd-24181e16ad46/20221021_2_2_0/ in table test_3.TestTbl (abc18f76-edc8-4dc8-8cbd-24181e16ad46) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x00000000130ebd1a 8. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:se190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x00000000130ebb0f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130eacce 10. /build/src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000130e21d0 11. /build/src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000130e24cb 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 13. /build/src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000017858cab 14. /build/src/Compression/CompressedReadBufferFromFile.cpp:25: DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000001785a8dd 15. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 16. /build/src/IO/ReadBuffer.h:96: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x0000000013c3a5d2 17. /build/src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000013ba04c3 18. /build/src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x00000000163b4199 19. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000163c87a0 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000163bc9b1 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::continueReadingChain(DB::MergeTreeRangeReader::ReadResult&, unsigned long&) @ 0x00000000163c47df 22. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:81: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x00000000163def61 23. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x00000000163dace0 24. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x0000000016d7ba8c 25. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5584 26. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 27. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 28. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 29. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 30. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 31. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:19:05.060306 [ 27539 ] {23f62413-b19d-4106-a50a-b2eb622f3469} executeQuery: Code: 469. DB::Exception: Constraint `cs_value2` for table test_9i6l1yio.table_for_rename (2ff6d713-a665-4f60-a5f5-0fb915f78930) is violated at row 1. Expression: (toInt64(value5) < toInt64(value3)). Column values: value5 = '11', value3 = '10'. (VIOLATED_CONSTRAINT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36734) (comment: 01277_alter_rename_column_constraint.sql) (query 12, line 29) (in query: INSERT INTO table_for_rename SELECT toDate('2019-10-01') + number % 3, number, toString(number), toString(number + 1), toString(number) from numbers(10, 10);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&) @ 0x0000000013bf7039 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000016b2113c 5. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 7. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 10. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 11. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 12. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 13. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168cfe81 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:19:05.074445 [ 27539 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `cs_value2` for table test_9i6l1yio.table_for_rename (2ff6d713-a665-4f60-a5f5-0fb915f78930) is violated at row 1. Expression: (toInt64(value5) < toInt64(value3)). Column values: value5 = '11', value3 = '10'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&) @ 0x0000000013bf7039 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000016b2113c 5. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 7. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 10. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 11. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 12. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 13. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168cfe81 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x00000000168cf907 5. /build/src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000001680710e 6. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 2025.07.13 02:19:06.334798 [ 30862 ] {674ffa87-6201-467a-897e-9f4faf8a927c} executeQuery: Code: 36. DB::Exception: index_granularity: value 0 makes no sense. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36910) (comment: 02514_bad_index_granularity.sql) (query 1, line 1) (in query: CREATE TABLE t (`id` Int64, `d` String, `p` Map(String, String)) ENGINE = ReplacingMergeTree ORDER BY id SETTINGS index_granularity = 0, min_bytes_for_wide_part = 380464293, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 228156859, compact_parts_max_granules_to_buffer = 3, compact_parts_merge_max_bytes_to_prefetch_part = 51457, merge_max_block_size = 2054, old_parts_lifetime = 333., prefer_fetch_merged_part_size_threshold = 4085965430, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 81, min_merge_bytes_to_use_direct_io = 10560096619, index_granularity_bytes = 9575821, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 73, 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 = 10095, primary_key_compress_block_size = 58537, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000a8668eb 4. /build/src/Storages/MergeTree/MergeTreeSettings.cpp:526: DB::MergeTreeSettingsImpl::sanityCheck(unsigned long, bool, bool) const @ 0x0000000016405120 5. /build/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) @ 0x00000000162251c9 6. /build/src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000016556b75 7. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000165568d0 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000165531fd 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ca1a22 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001481ee32 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:19:06.344764 [ 30862 ] {} TCPHandler: Code: 36. DB::Exception: index_granularity: value 0 makes no sense. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000a8668eb 4. /build/src/Storages/MergeTree/MergeTreeSettings.cpp:526: DB::MergeTreeSettingsImpl::sanityCheck(unsigned long, bool, bool) const @ 0x0000000016405120 5. /build/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) @ 0x00000000162251c9 6. /build/src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000016556b75 7. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000165568d0 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000165531fd 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ca1a22 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001481ee32 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 15. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 16. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 21. ? @ 0x00007f7210eb6ac3 22. ? @ 0x00007f7210f48850 2025.07.13 02:19:08.325116 [ 39696 ] {} ExternalDictionariesLoader: Could not load external dictionary '02ea2b3a-7cb3-4b74-abb1-4f80305a92a9', next update is scheduled at 2025-07-13 02:19:26: Code: 482. DB::Exception: Dictionaries with executable dictionary source are not allowed to be created from DDL query. (DICTIONARY_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Dictionaries/ExecutableDictionarySource.cpp:233: std::shared_ptr std::__function::__policy_invoker (DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr, String const&, bool)>::__call_impl[abi:se190107] (DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr, String const&, bool)>>(std::__function::__policy_storage const*, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr&&, String const&, bool) @ 0x00000000119c8c6b 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012c76e33 6. /build/src/Dictionaries/DictionaryFactory.cpp:47: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x0000000012c74a2d 7. /build/src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000147cade4 8. /build/src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000147d6c48 9. /build/src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000147d56dd 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000147d96f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:19:08.411871 [ 4888 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c1743ab 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013779083 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778c58 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168167bf 10. /build/src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000001680ff45 11. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:19:08.415593 [ 4888 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x0000000016810069 5. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 6. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 2025.07.13 02:19:09.424073 [ 30862 ] {21cc7ea1-0359-4e8c-b227-c6e8569ecc60} executeQuery: Code: 47. DB::Exception: Missing columns: 'nonexistent' while processing: 'isZeroOrNull(nonexistent = 0), _block_number, _partition_value, _part_data_version, _partition_id, _part_index, _part, s, m, _part_offset, _sample_factor, x, _block_offset, _part_uuid, d', required columns: 'nonexistent' '_partition_id' '_block_number' '_partition_value' '_part_data_version' '_part_index' '_part' 's' 'm' '_part_offset' 'x' '_sample_factor' '_block_offset' '_part_uuid' 'd', maybe you meant: 's', 'm', 'x' or 'd'. (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56542) (comment: 00652_replicated_mutations_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE mutations_r1 DELETE WHERE nonexistent = 0), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Interpreters/TreeRewriter.cpp:1303: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x0000000014b1fec8 4. /build/src/Interpreters/TreeRewriter.cpp:1561: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x0000000014b28338 5. /build/src/Interpreters/MutationsInterpreter.cpp:1177: DB::MutationsInterpreter::prepareMutationStages(std::vector>&, bool) @ 0x000000001494c9eb 6. /build/src/Interpreters/MutationsInterpreter.cpp:1094: DB::MutationsInterpreter::prepare(bool) @ 0x00000000149498ad 7. /build/src/Interpreters/MutationsInterpreter.cpp:405: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x000000001494343c 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:235: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd34e 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:19:09.484155 [ 30862 ] {} TCPHandler: Code: 47. DB::Exception: Missing columns: 'nonexistent' while processing: 'isZeroOrNull(nonexistent = 0), _block_number, _partition_value, _part_data_version, _partition_id, _part_index, _part, s, m, _part_offset, _sample_factor, x, _block_offset, _part_uuid, d', required columns: 'nonexistent' '_partition_id' '_block_number' '_partition_value' '_part_data_version' '_part_index' '_part' 's' 'm' '_part_offset' 'x' '_sample_factor' '_block_offset' '_part_uuid' 'd', maybe you meant: 's', 'm', 'x' or 'd'. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Interpreters/TreeRewriter.cpp:1303: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x0000000014b1fec8 4. /build/src/Interpreters/TreeRewriter.cpp:1561: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x0000000014b28338 5. /build/src/Interpreters/MutationsInterpreter.cpp:1177: DB::MutationsInterpreter::prepareMutationStages(std::vector>&, bool) @ 0x000000001494c9eb 6. /build/src/Interpreters/MutationsInterpreter.cpp:1094: DB::MutationsInterpreter::prepare(bool) @ 0x00000000149498ad 7. /build/src/Interpreters/MutationsInterpreter.cpp:405: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x000000001494343c 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:235: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd34e 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:19:09.688048 [ 27539 ] {32dd02b3-5919-4533-85cf-3d6cf63634c2} executeQuery: Code: 469. DB::Exception: Constraint `cs_value1` for table test_9i6l1yio.table_for_rename (2ff6d713-a665-4f60-a5f5-0fb915f78930) is violated at row 1. Expression: (toInt64(value1) < toInt64(value2)). Column values: value1 = '20', value2 = '20'. (VIOLATED_CONSTRAINT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36734) (comment: 01277_alter_rename_column_constraint.sql) (query 21, line 40) (in query: INSERT INTO table_for_rename SELECT toDate('2019-10-01') + number % 3, number, toString(number), toString(number), toString(number + 2) from numbers(20, 10);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&) @ 0x0000000013bf7039 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000016b2113c 5. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 7. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 10. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 11. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 12. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 13. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168cfe81 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:19:09.698897 [ 27539 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `cs_value1` for table test_9i6l1yio.table_for_rename (2ff6d713-a665-4f60-a5f5-0fb915f78930) is violated at row 1. Expression: (toInt64(value1) < toInt64(value2)). Column values: value1 = '20', value2 = '20'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&) @ 0x0000000013bf7039 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000016b2113c 5. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016b2fe09 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016b2fc75 7. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016b2f77e 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 10. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 11. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 12. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 13. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168cfe81 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x00000000168cf907 5. /build/src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000001680710e 6. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 2025.07.13 02:19:10.202595 [ 37316 ] {22950a81-ce78-4546-956f-b09d201ea23b} executeQuery: Code: 38. DB::Exception: Cannot parse date: value is too short: while converting '11' to Date: while executing 'FUNCTION equals(d : 0, '11' : 1) -> equals(d, '11') UInt8 : 2'. (CANNOT_PARSE_DATE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56604) (comment: 00652_replicated_mutations_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE mutations_r1 DELETE WHERE d = '11'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/IO/ReadHelpers.cpp:1389: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000000fb8dc5d 5. /build/src/IO/ReadHelpers.h:850: DB::SerializationDate::deserializeTextEscaped(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013bb0faa 6. /build/src/DataTypes/Serializations/SerializationDate.cpp:20: DB::SerializationDate::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013bb0efe 7. /build/src/Interpreters/convertFieldToType.cpp:578: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014b775e9 8. /build/src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014b75587 9. /build/src/Functions/FunctionsComparison.h:925: DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b588271 10. /build/src/Functions/FunctionsComparison.h:1361: DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b56f65f 11. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 16. /build/src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x000000001443c9fb 17. /build/src/Interpreters/ExpressionAnalyzer.cpp:2086: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x000000001445de37 18. /build/src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x00000000148700e8 19. /build/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 @ 0x00000000148674c4 20. /build/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) @ 0x0000000014862327 21. /build/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) @ 0x000000001485ec6c 22. /build/src/Interpreters/InterpreterSelectQuery.cpp:330: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014864d54 23. /build/src/Interpreters/MutationsInterpreter.cpp:1440: DB::MutationsInterpreter::validate() @ 0x000000001495059c 24. /build/src/Interpreters/InterpreterAlterQuery.cpp:235: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd35b 25. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 26. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 28. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 29. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 2025.07.13 02:19:10.292760 [ 37316 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date: value is too short: while converting '11' to Date: while executing 'FUNCTION equals(d : 0, '11' : 1) -> equals(d, '11') UInt8 : 2'. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/IO/ReadHelpers.cpp:1389: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000000fb8dc5d 5. /build/src/IO/ReadHelpers.h:850: DB::SerializationDate::deserializeTextEscaped(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013bb0faa 6. /build/src/DataTypes/Serializations/SerializationDate.cpp:20: DB::SerializationDate::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013bb0efe 7. /build/src/Interpreters/convertFieldToType.cpp:578: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014b775e9 8. /build/src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014b75587 9. /build/src/Functions/FunctionsComparison.h:925: DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b588271 10. /build/src/Functions/FunctionsComparison.h:1361: DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b56f65f 11. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 16. /build/src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x000000001443c9fb 17. /build/src/Interpreters/ExpressionAnalyzer.cpp:2086: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x000000001445de37 18. /build/src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x00000000148700e8 19. /build/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 @ 0x00000000148674c4 20. /build/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) @ 0x0000000014862327 21. /build/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) @ 0x000000001485ec6c 22. /build/src/Interpreters/InterpreterSelectQuery.cpp:330: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014864d54 23. /build/src/Interpreters/MutationsInterpreter.cpp:1440: DB::MutationsInterpreter::validate() @ 0x000000001495059c 24. /build/src/Interpreters/InterpreterAlterQuery.cpp:235: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd35b 25. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 26. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 28. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 29. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 2025.07.13 02:19:12.476842 [ 3778 ] {} DNSResolver: Cannot resolve host (localhos), error 0: Host not found. 2025.07.13 02:19:13.545435 [ 5822 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:19:13.773092 [ 37313 ] {test_cl5bnuxuhello} 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]:48926) (comment: 00600_replace_running_query.sh) (in query: SELECT 1, count() FROM system.numbers), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000001496a8c5 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000001496a819 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x000000001496af0d 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000168d1a5a 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0c24 9. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000168cfa64 10. /build/src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014bab0a3 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:19:13.780138 [ 37313 ] {test_cl5bnuxuhello} DynamicQueryHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000001496a8c5 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000001496a819 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x000000001496af0d 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000168d1a5a 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0c24 9. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000168cfa64 10. /build/src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014bab0a3 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:19:15.556588 [ 4267 ] {} f7f5cc75-376d-494e-93fd-e8154fa94f91::20000201_20000201_0_0_0_2 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 9. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000001494103a 7. /build/src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000016450695 8. /build/src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x000000001644fcf1 9. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:217: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x00000000164ae2bd 10. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x00000000164acf56 11. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 12. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 14. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:19:15.560410 [ 4267 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {f7f5cc75-376d-494e-93fd-e8154fa94f91::20000201_20000201_0_0_0_2}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 9. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000001494103a 7. /build/src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000016450695 8. /build/src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x000000001644fcf1 9. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:217: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x00000000164ae2bd 10. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x00000000164acf56 11. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 12. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 14. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:19:15.796295 [ 16757 ] {test_cl5bnuxu42} executeQuery: Code: 216. DB::Exception: Query with id = test_cl5bnuxu42 is already running by user u_00600test_cl5bnuxu. (QUERY_WITH_SAME_ID_IS_ALREADY_RUNNING) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56684) (comment: 00600_replace_running_query.sh) (query 1, line 1) (in query: SELECT 43), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&) @ 0x000000000fd73e4b 4. /build/src/Interpreters/ProcessList.cpp:240: DB::ProcessList::insert(String const&, unsigned long, DB::IAST const*, std::shared_ptr, unsigned long) @ 0x0000000014967aec 5. /build/src/Interpreters/executeQuery.cpp:1180: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba43e8 6. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 7. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:19:15.824343 [ 16757 ] {} TCPHandler: Code: 216. DB::Exception: Query with id = test_cl5bnuxu42 is already running by user u_00600test_cl5bnuxu. (QUERY_WITH_SAME_ID_IS_ALREADY_RUNNING), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&) @ 0x000000000fd73e4b 4. /build/src/Interpreters/ProcessList.cpp:240: DB::ProcessList::insert(String const&, unsigned long, DB::IAST const*, std::shared_ptr, unsigned long) @ 0x0000000014967aec 5. /build/src/Interpreters/executeQuery.cpp:1180: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba43e8 6. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 7. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:19:16.036399 [ 6619 ] {test_cl5bnuxu42} executeQuery: Code: 216. DB::Exception: Query with id = test_cl5bnuxu42 is already running by user u_00600test_cl5bnuxu. (QUERY_WITH_SAME_ID_IS_ALREADY_RUNNING) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:48972) (comment: 00600_replace_running_query.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&) @ 0x000000000fd73e4b 4. /build/src/Interpreters/ProcessList.cpp:240: DB::ProcessList::insert(String const&, unsigned long, DB::IAST const*, std::shared_ptr, unsigned long) @ 0x0000000014967aec 5. /build/src/Interpreters/executeQuery.cpp:1180: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba43e8 6. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 7. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 8. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 9. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 2025.07.13 02:19:16.039797 [ 6619 ] {test_cl5bnuxu42} DynamicQueryHandler: Code: 216. DB::Exception: Query with id = test_cl5bnuxu42 is already running by user u_00600test_cl5bnuxu. (QUERY_WITH_SAME_ID_IS_ALREADY_RUNNING), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&) @ 0x000000000fd73e4b 4. /build/src/Interpreters/ProcessList.cpp:240: DB::ProcessList::insert(String const&, unsigned long, DB::IAST const*, std::shared_ptr, unsigned long) @ 0x0000000014967aec 5. /build/src/Interpreters/executeQuery.cpp:1180: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba43e8 6. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 7. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 8. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 9. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 14. ? @ 0x00007f7210eb6ac3 15. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:19:16.563423 [ 31799 ] {9b2ed7de-050e-4be5-a6d8-7a9238f42044} executeQuery: Code: 42. DB::Exception: Function sqidEncode requires at least one argument.: In scope SELECT sqidEncode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56688) (comment: 02933_sqid.sql) (query 3, line 6) (in query: SELECT sqidEncode();), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/sqid.cpp:43: DB::FunctionSqidEncode::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000e6026b6 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:19:16.563868 [ 37313 ] {test_cl5bnuxu42} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56678) (query 1, line 1) (in query: SELECT 2, count() FROM system.numbers), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000001496a8c5 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000001496a819 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x000000001496af0d 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000168d1a5a 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0c24 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 12. ? @ 0x00007f7210eb6ac3 13. ? @ 0x00007f7210f48850 2025.07.13 02:19:16.572232 [ 31799 ] {} TCPHandler: Code: 42. DB::Exception: Function sqidEncode requires at least one argument.: In scope SELECT sqidEncode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/sqid.cpp:43: DB::FunctionSqidEncode::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000e6026b6 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:19:16.613581 [ 37313 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000001496a8c5 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000001496a819 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x000000001496af0d 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000168d1a5a 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0c24 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 12. ? @ 0x00007f7210eb6ac3 13. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:19:16.767500 [ 31799 ] {ae614c44-b1e0-4f96-a0a6-3978e6c4b011} executeQuery: Code: 42. DB::Exception: Number of arguments for function sqidDecode doesn't match: passed 0, should be 1: In scope SELECT sqidDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56688) (comment: 02933_sqid.sql) (query 4, line 7) (in query: SELECT sqidDecode();), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000011fa678b 4. /build/src/Functions/IFunction.cpp:539: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000012c80d4d 5. /build/src/Functions/IFunction.cpp:593: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c81533 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:19:16.778649 [ 31799 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sqidDecode doesn't match: passed 0, should be 1: In scope SELECT sqidDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000011fa678b 4. /build/src/Functions/IFunction.cpp:539: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000012c80d4d 5. /build/src/Functions/IFunction.cpp:593: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c81533 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:19:17.107478 [ 31799 ] {277b059b-a612-43a5-9a7f-06f9f4cde202} executeQuery: Code: 43. DB::Exception: Argument 0 for function sqidEncode must have datatype UInt*, given type: String.: In scope SELECT sqidEncode('1'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56688) (comment: 02933_sqid.sql) (query 5, line 8) (in query: SELECT sqidEncode('1');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, String&&, String&&) @ 0x000000000e603ceb 4. /build/src/Functions/sqid.cpp:52: DB::FunctionSqidEncode::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000e602620 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:19:17.126693 [ 31799 ] {} TCPHandler: Code: 43. DB::Exception: Argument 0 for function sqidEncode must have datatype UInt*, given type: String.: In scope SELECT sqidEncode('1'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, String&&, String&&) @ 0x000000000e603ceb 4. /build/src/Functions/sqid.cpp:52: DB::FunctionSqidEncode::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000e602620 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:19:17.381079 [ 31799 ] {e0cc2922-251d-4a27-8ca3-8756a57b6e5c} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'sqid' to function 'sqidDecode'. Expected: String, got: UInt8: In scope SELECT sqidDecode(1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56688) (comment: 02933_sqid.sql) (query 6, line 9) (in query: SELECT sqidDecode(1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/sqid.cpp:108: DB::FunctionSqidDecode::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e604dab 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:19:17.394935 [ 31799 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'sqid' to function 'sqidDecode'. Expected: String, got: UInt8: In scope SELECT sqidDecode(1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/sqid.cpp:108: DB::FunctionSqidDecode::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e604dab 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:19:18.421587 [ 31788 ] {0a8e8526-7da1-40c0-9a5d-625f847b7390} 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]:56706) (comment: 01715_background_checker_blather_zookeeper_long.sql) (query 3, line 7) (in query: CREATE TABLE i20203_1 (`a` Int8) ENGINE = ReplicatedMergeTree('/clickhouse/{database}/01715_background_checker_i20203', 'r1') ORDER BY tuple() SETTINGS index_granularity = 55900, min_bytes_for_wide_part = 450289316, 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 = 155164609, compact_parts_max_granules_to_buffer = 167, compact_parts_merge_max_bytes_to_prefetch_part = 27381828, merge_max_block_size = 6250, old_parts_lifetime = 359., 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 = 1, index_granularity_bytes = 8199931, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 56, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 59421, primary_key_compress_block_size = 34046, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000013cc1696 5. /build/src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013cc32f5 6. /build/src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc384b 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:19:18.486505 [ 31788 ] {} TCPHandler: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000013cc1696 5. /build/src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013cc32f5 6. /build/src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc384b 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:19:18.585557 [ 47958 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:19:18.729347 [ 37316 ] {test_cl5bnuxu42} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56702) (comment: 00600_replace_running_query.sh) (query 1, line 1) (in query: SELECT 3, count() FROM system.numbers), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000001496a8c5 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000001496a819 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x000000001496af0d 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000168d1a5a 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0c24 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 12. ? @ 0x00007f7210eb6ac3 13. ? @ 0x00007f7210f48850 2025.07.13 02:19:18.747690 [ 37316 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000001496a8c5 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000001496a819 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x000000001496af0d 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000168d1a5a 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0c24 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 12. ? @ 0x00007f7210eb6ac3 13. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:19:20.508439 [ 6619 ] {0c302a18-a1a4-4641-9ed7-9cefbd70ca6c} executeQuery: Code: 47. DB::Exception: Unknown qualified identifier: insert_select_src: While processing insert_select_src.* EXCEPT (middle_a, middle_b). (UNKNOWN_IDENTIFIER) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56708) (comment: 01470_test_insert_select_asterisk.sql) (query 9, line 13) (in query: INSERT INTO insert_select_dst(insert_select_src.* EXCEPT (middle_a, middle_b)) SELECT * FROM insert_select_src;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Interpreters/TranslateQualifiedNamesVisitor.cpp:172: DB::TranslateQualifiedNamesMatcher::visit(DB::ASTQualifiedAsterisk const&, std::shared_ptr const&, DB::TranslateQualifiedNamesMatcher::Data&) @ 0x0000000014b5ec5e 5. /build/src/Interpreters/TranslateQualifiedNamesVisitor.cpp:227: DB::TranslateQualifiedNamesMatcher::visit(DB::ASTExpressionList&, std::shared_ptr const&, DB::TranslateQualifiedNamesMatcher::Data&) @ 0x0000000014b5e746 6. /build/src/Interpreters/TranslateQualifiedNamesVisitor.cpp:113: DB::TranslateQualifiedNamesMatcher::visit(std::shared_ptr&, DB::TranslateQualifiedNamesMatcher::Data&) @ 0x0000000014b5d583 7. /build/src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x0000000014b2ddd5 8. /build/src/Interpreters/InDepthNodeVisitor.h:61: DB::processColumnTransformers(String const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000014bedccd 9. /build/src/Interpreters/InterpreterInsertQuery.cpp:210: DB::InterpreterInsertQuery::getInsertColumnNames() const @ 0x000000001484b544 10. /build/src/Interpreters/executeQuery.cpp:1436: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6a60 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:19:20.516517 [ 6619 ] {} TCPHandler: Code: 47. DB::Exception: Unknown qualified identifier: insert_select_src: While processing insert_select_src.* EXCEPT (middle_a, middle_b). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Interpreters/TranslateQualifiedNamesVisitor.cpp:172: DB::TranslateQualifiedNamesMatcher::visit(DB::ASTQualifiedAsterisk const&, std::shared_ptr const&, DB::TranslateQualifiedNamesMatcher::Data&) @ 0x0000000014b5ec5e 5. /build/src/Interpreters/TranslateQualifiedNamesVisitor.cpp:227: DB::TranslateQualifiedNamesMatcher::visit(DB::ASTExpressionList&, std::shared_ptr const&, DB::TranslateQualifiedNamesMatcher::Data&) @ 0x0000000014b5e746 6. /build/src/Interpreters/TranslateQualifiedNamesVisitor.cpp:113: DB::TranslateQualifiedNamesMatcher::visit(std::shared_ptr&, DB::TranslateQualifiedNamesMatcher::Data&) @ 0x0000000014b5d583 7. /build/src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x0000000014b2ddd5 8. /build/src/Interpreters/InDepthNodeVisitor.h:61: DB::processColumnTransformers(String const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000014bedccd 9. /build/src/Interpreters/InterpreterInsertQuery.cpp:210: DB::InterpreterInsertQuery::getInsertColumnNames() const @ 0x000000001484b544 10. /build/src/Interpreters/executeQuery.cpp:1436: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6a60 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 12. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 13. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:19:23.823559 [ 4858 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:19:25.417272 [ 37313 ] {5553322a-e124-4abd-ad58-efe7fec70d53} executeQuery: Code: 36. DB::Exception: Needle must not contain whitespace or separator characters: while executing 'FUNCTION hasToken(s : 0, 'abc,def,zzz'_String :: 1) -> hasToken(__table1.s, 'abc,def,zzz'_String) UInt8 : 2': While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57452) (comment: 00990_hasToken_and_tokenbf.sql) (query 7, line 15) (in query: SELECT max(id) FROM bloom_filter WHERE hasToken(s, 'abc,def,zzz');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/HasTokenImpl.h:60: DB::HasTokenImpl>, false>::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) @ 0x000000000c1596c1 5. /build/src/Functions/FunctionsStringSearch.h:326: DB::FunctionsStringSearch>, false>, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c1579f6 6. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 7. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 10. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 11. /build/src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x000000001443c9fb 12. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:1394: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) const @ 0x00000000163c5d35 13. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:110: DB::MergeTreeReadersChain::executePrewhereActions(DB::MergeTreeRangeReader&, DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) @ 0x00000000163df584 14. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:75: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x00000000163dedc4 15. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x00000000163dace0 16. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x0000000016d7ba8c 17. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5584 18. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 19. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 20. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 21. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 22. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 23. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 25. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:19:25.472159 [ 37313 ] {} TCPHandler: Code: 36. DB::Exception: Needle must not contain whitespace or separator characters: while executing 'FUNCTION hasToken(s : 0, 'abc,def,zzz'_String :: 1) -> hasToken(__table1.s, 'abc,def,zzz'_String) UInt8 : 2': While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/HasTokenImpl.h:60: DB::HasTokenImpl>, false>::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) @ 0x000000000c1596c1 5. /build/src/Functions/FunctionsStringSearch.h:326: DB::FunctionsStringSearch>, false>, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c1579f6 6. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 7. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 10. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 11. /build/src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x000000001443c9fb 12. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:1394: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) const @ 0x00000000163c5d35 13. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:110: DB::MergeTreeReadersChain::executePrewhereActions(DB::MergeTreeRangeReader&, DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) @ 0x00000000163df584 14. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:75: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x00000000163dedc4 15. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x00000000163dace0 16. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x0000000016d7ba8c 17. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5584 18. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 19. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 20. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 21. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 22. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 23. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 25. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:19:26.081414 [ 37313 ] {16960f4a-966e-4eb3-9142-77697f6d2ef4} executeQuery: Code: 36. DB::Exception: Needle must not contain whitespace or separator characters: while executing 'FUNCTION hasTokenCaseInsensitive(s : 0, 'abc,def,zzz'_String :: 1) -> hasTokenCaseInsensitive(__table1.s, 'abc,def,zzz'_String) UInt8 : 2': While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57452) (comment: 00990_hasToken_and_tokenbf.sql) (query 8, line 16) (in query: SELECT max(id) FROM bloom_filter WHERE hasTokenCaseInsensitive(s, 'abc,def,zzz');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/HasTokenImpl.h:60: DB::HasTokenImpl>, false>::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) @ 0x000000000c15e8a1 5. /build/src/Functions/FunctionsStringSearch.h:326: DB::FunctionsStringSearch>, false>, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c15cbd6 6. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 7. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 10. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 11. /build/src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x000000001443c9fb 12. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:1394: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) const @ 0x00000000163c5d35 13. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:110: DB::MergeTreeReadersChain::executePrewhereActions(DB::MergeTreeRangeReader&, DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) @ 0x00000000163df584 14. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:75: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x00000000163dedc4 15. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x00000000163dace0 16. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x0000000016d7ba8c 17. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5584 18. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 19. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 20. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 21. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 22. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 23. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 25. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:19:26.120281 [ 37313 ] {} TCPHandler: Code: 36. DB::Exception: Needle must not contain whitespace or separator characters: while executing 'FUNCTION hasTokenCaseInsensitive(s : 0, 'abc,def,zzz'_String :: 1) -> hasTokenCaseInsensitive(__table1.s, 'abc,def,zzz'_String) UInt8 : 2': While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/HasTokenImpl.h:60: DB::HasTokenImpl>, false>::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) @ 0x000000000c15e8a1 5. /build/src/Functions/FunctionsStringSearch.h:326: DB::FunctionsStringSearch>, false>, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c15cbd6 6. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f3a 7. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e492 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 10. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001443b733 11. /build/src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x000000001443c9fb 12. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:1394: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) const @ 0x00000000163c5d35 13. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:110: DB::MergeTreeReadersChain::executePrewhereActions(DB::MergeTreeRangeReader&, DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) @ 0x00000000163df584 14. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:75: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x00000000163dedc4 15. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x00000000163dace0 16. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x0000000016d7ba8c 17. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5584 18. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 19. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 20. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 21. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 22. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 23. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 25. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:19:28.563923 [ 5877 ] {7ee9bc84-41d2-41ce-bb08-5f78f68fead3} 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]:57598) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000009fbd84b 4. /build/src/Functions/array/FunctionArrayMapped.h:155: DB::FunctionArrayMapped::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x000000000e96c53a 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3389: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f50cde 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 11. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 12. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 17. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 19. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 20. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 2025.07.13 02:19:28.575879 [ 5877 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000009fbd84b 4. /build/src/Functions/array/FunctionArrayMapped.h:155: DB::FunctionArrayMapped::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x000000000e96c53a 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3389: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f50cde 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 11. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 12. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 17. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 19. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 20. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 2025.07.13 02:19:28.602202 [ 31788 ] {a0c1b4ac-0b5b-4751-bdb1-539e0a616d37} executeQuery: Code: 43. DB::Exception: Datetime argument and origin argument for function toStartOfInterval must have the same type: In scope SELECT toStartOfInterval(toDate('2023-01-02 14:45:50'), toIntervalSecond(5), toDate32('2023-01-02 14:44:30')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57622) (comment: 02916_to_start_of_interval_with_origin.sql) (query 3, line 5) (in query: -- time and origin arguments must have the same type SELECT toStartOfInterval(toDate('2023-01-02 14:45:50'), toIntervalSecond(5), toDate32('2023-01-02 14:44:30'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/toStartOfInterval.cpp:134: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const::'lambda1'()::operator()() const @ 0x000000000e7d1ae1 5. /build/src/Functions/toStartOfInterval.cpp:169: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e79ba24 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:19:28.617424 [ 31788 ] {} TCPHandler: Code: 43. DB::Exception: Datetime argument and origin argument for function toStartOfInterval must have the same type: In scope SELECT toStartOfInterval(toDate('2023-01-02 14:45:50'), toIntervalSecond(5), toDate32('2023-01-02 14:44:30')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/toStartOfInterval.cpp:134: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const::'lambda1'()::operator()() const @ 0x000000000e7d1ae1 5. /build/src/Functions/toStartOfInterval.cpp:169: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e79ba24 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:19:28.653388 [ 5877 ] {ba29b589-7a55-4f24-814f-2cdebe89a400} 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]:57598) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000009fbd84b 4. /build/src/Functions/array/FunctionArrayMapped.h:155: DB::FunctionArrayMapped::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x000000000e96c53a 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3389: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f50cde 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 11. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 12. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 17. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 19. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 20. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 2025.07.13 02:19:28.662094 [ 5877 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000009fbd84b 4. /build/src/Functions/array/FunctionArrayMapped.h:155: DB::FunctionArrayMapped::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x000000000e96c53a 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3389: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f50cde 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 11. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 12. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 17. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 19. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 20. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 2025.07.13 02:19:28.702362 [ 47951 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:19:28.706099 [ 10910 ] {} ExternalDictionariesLoader: Could not load external dictionary '02ea2b3a-7cb3-4b74-abb1-4f80305a92a9', next update is scheduled at 2025-07-13 02:19:47: Code: 482. DB::Exception: Dictionaries with executable dictionary source are not allowed to be created from DDL query. (DICTIONARY_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Dictionaries/ExecutableDictionarySource.cpp:233: std::shared_ptr std::__function::__policy_invoker (DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr, String const&, bool)>::__call_impl[abi:se190107] (DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr, String const&, bool)>>(std::__function::__policy_storage const*, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr&&, String const&, bool) @ 0x00000000119c8c6b 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012c76e33 6. /build/src/Dictionaries/DictionaryFactory.cpp:47: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x0000000012c74a2d 7. /build/src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000147cade4 8. /build/src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000147d6c48 9. /build/src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000147d56dd 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000147d96f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:19:28.732566 [ 31788 ] {ade85175-2a3e-4e94-8221-8d5560a32a8f} executeQuery: Code: 43. DB::Exception: Datetime argument and origin argument for function toStartOfInterval must have the same type: In scope SELECT toStartOfInterval(toDate('2023-01-02 14:45:50'), toIntervalMillisecond(12), toDateTime('2023-01-02 14:44:30')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57622) (comment: 02916_to_start_of_interval_with_origin.sql) (query 4, line 7) (in query: SELECT toStartOfInterval(toDate('2023-01-02 14:45:50'), toIntervalMillisecond(12), toDateTime('2023-01-02 14:44:30'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/toStartOfInterval.cpp:134: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const::'lambda1'()::operator()() const @ 0x000000000e7d1ae1 5. /build/src/Functions/toStartOfInterval.cpp:169: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e79ba24 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:19:28.748856 [ 31788 ] {} TCPHandler: Code: 43. DB::Exception: Datetime argument and origin argument for function toStartOfInterval must have the same type: In scope SELECT toStartOfInterval(toDate('2023-01-02 14:45:50'), toIntervalMillisecond(12), toDateTime('2023-01-02 14:44:30')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/toStartOfInterval.cpp:134: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const::'lambda1'()::operator()() const @ 0x000000000e7d1ae1 5. /build/src/Functions/toStartOfInterval.cpp:169: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e79ba24 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:19:28.982410 [ 31788 ] {e6dac77c-e34f-4c68-89d3-02c8ebf40f73} executeQuery: Code: 43. DB::Exception: Datetime argument and origin argument for function toStartOfInterval must have the same type: In scope SELECT toStartOfInterval(toDate32('2023-01-02 14:45:50'), toIntervalHour(5), toDate('2023-01-02 14:44:30')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57622) (comment: 02916_to_start_of_interval_with_origin.sql) (query 5, line 8) (in query: SELECT toStartOfInterval(toDate32('2023-01-02 14:45:50'), toIntervalHour(5), toDate('2023-01-02 14:44:30'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/toStartOfInterval.cpp:134: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const::'lambda1'()::operator()() const @ 0x000000000e7d1ae1 5. /build/src/Functions/toStartOfInterval.cpp:169: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e79ba24 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:19:28.993461 [ 31788 ] {} TCPHandler: Code: 43. DB::Exception: Datetime argument and origin argument for function toStartOfInterval must have the same type: In scope SELECT toStartOfInterval(toDate32('2023-01-02 14:45:50'), toIntervalHour(5), toDate('2023-01-02 14:44:30')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/toStartOfInterval.cpp:134: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const::'lambda1'()::operator()() const @ 0x000000000e7d1ae1 5. /build/src/Functions/toStartOfInterval.cpp:169: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e79ba24 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:19:29.200949 [ 31788 ] {88bf90d9-8bd2-429a-907a-8a466274aea8} executeQuery: Code: 43. DB::Exception: Datetime argument and origin argument for function toStartOfInterval must have the same type: In scope SELECT toStartOfInterval(toDateTime('2023-01-02 14:45:50'), toIntervalMinute(1), toDateTime64('2023-01-02 14:44:30', 2)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57622) (comment: 02916_to_start_of_interval_with_origin.sql) (query 6, line 9) (in query: SELECT toStartOfInterval(toDateTime('2023-01-02 14:45:50'), toIntervalMinute(1), toDateTime64('2023-01-02 14:44:30', 2));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/toStartOfInterval.cpp:134: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const::'lambda1'()::operator()() const @ 0x000000000e7d1ae1 5. /build/src/Functions/toStartOfInterval.cpp:169: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e79ba24 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:19:29.218743 [ 31788 ] {} TCPHandler: Code: 43. DB::Exception: Datetime argument and origin argument for function toStartOfInterval must have the same type: In scope SELECT toStartOfInterval(toDateTime('2023-01-02 14:45:50'), toIntervalMinute(1), toDateTime64('2023-01-02 14:44:30', 2)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/toStartOfInterval.cpp:134: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const::'lambda1'()::operator()() const @ 0x000000000e7d1ae1 5. /build/src/Functions/toStartOfInterval.cpp:169: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e79ba24 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:19:29.335823 [ 31788 ] {75102e61-b9ca-4aea-9750-e132c18e4710} executeQuery: Code: 43. DB::Exception: Datetime argument and origin argument for function toStartOfInterval must have the same type: In scope SELECT toStartOfInterval(toDateTime64('2023-01-02 14:45:50', 2), toIntervalMinute(1), toDate('2023-01-02 14:44:30')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57622) (comment: 02916_to_start_of_interval_with_origin.sql) (query 7, line 10) (in query: SELECT toStartOfInterval(toDateTime64('2023-01-02 14:45:50', 2), toIntervalMinute(1), toDate('2023-01-02 14:44:30'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/toStartOfInterval.cpp:134: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const::'lambda1'()::operator()() const @ 0x000000000e7d1ae1 5. /build/src/Functions/toStartOfInterval.cpp:169: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e79ba24 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:19:29.446608 [ 31788 ] {} TCPHandler: Code: 43. DB::Exception: Datetime argument and origin argument for function toStartOfInterval must have the same type: In scope SELECT toStartOfInterval(toDateTime64('2023-01-02 14:45:50', 2), toIntervalMinute(1), toDate('2023-01-02 14:44:30')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Functions/toStartOfInterval.cpp:134: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const::'lambda1'()::operator()() const @ 0x000000000e7d1ae1 5. /build/src/Functions/toStartOfInterval.cpp:169: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e79ba24 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:19:29.716428 [ 31788 ] {d99e5a3e-4d87-4cfa-ae8b-a0102f426428} executeQuery: Code: 36. DB::Exception: The origin must be before the end date / date with time: In scope SELECT toStartOfInterval(toDateTime('2023-01-02 14:42:50'), toIntervalMinute(1), toDateTime('2023-01-02 14:44:30')). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57622) (comment: 02916_to_start_of_interval_with_origin.sql) (query 8, line 12) (in query: -- the origin must be before the time SELECT toStartOfInterval(toDateTime('2023-01-02 14:42:50'), toIntervalMinute(1), toDateTime('2023-01-02 14:44:30'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/toStartOfInterval.cpp:397: COW::immutable_ptr DB::FunctionToStartOfInterval::execute, (DB::IntervalKind::Kind)4>(DB::DataTypeDateTime const&, DB::ColumnVector const&, long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e7bf4cb 5. /build/src/Functions/toStartOfInterval.cpp:337: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDateTime const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e7b8650 6. /build/src/Functions/toStartOfInterval.cpp:278: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e79c619 7. /build/src/Functions/toStartOfInterval.cpp:247: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e79b587 8. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 9. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 29. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 30. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 2025.07.13 02:19:29.734677 [ 31788 ] {} TCPHandler: Code: 36. DB::Exception: The origin must be before the end date / date with time: In scope SELECT toStartOfInterval(toDateTime('2023-01-02 14:42:50'), toIntervalMinute(1), toDateTime('2023-01-02 14:44:30')). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/toStartOfInterval.cpp:397: COW::immutable_ptr DB::FunctionToStartOfInterval::execute, (DB::IntervalKind::Kind)4>(DB::DataTypeDateTime const&, DB::ColumnVector const&, long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e7bf4cb 5. /build/src/Functions/toStartOfInterval.cpp:337: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDateTime const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e7b8650 6. /build/src/Functions/toStartOfInterval.cpp:278: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e79c619 7. /build/src/Functions/toStartOfInterval.cpp:247: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e79b587 8. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 9. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 29. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 30. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 2025.07.13 02:19:30.083461 [ 31788 ] {89962930-5c75-4d68-8a76-0814ba03e001} executeQuery: Code: 44. DB::Exception: Argument at index 2 for function toStartOfInterval must be constant. (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57622) (comment: 02916_to_start_of_interval_with_origin.sql) (query 9, line 15) (in query: -- the origin must be constant SELECT toStartOfInterval(toDateTime('2023-01-02 14:45:50'), toIntervalMinute(1), number % 2 == 0 ? toDateTime('2023-02-01 15:55:00') : toDateTime('2023-01-01 15:55:00')) from numbers(1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000b97110b 4. /build/src/Functions/IFunction.cpp:141: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dab8 5. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 6. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 7. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 8. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013ec18ac 9. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013ec09aa 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016b30052 11. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016cdda71 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000130d8a1a 13. /build/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>>&) @ 0x00000000148a05bd 14. /build/src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000001489a16a 15. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 17. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 19. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 20. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 2025.07.13 02:19:30.111682 [ 31788 ] {} TCPHandler: Code: 44. DB::Exception: Argument at index 2 for function toStartOfInterval must be constant. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000b97110b 4. /build/src/Functions/IFunction.cpp:141: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dab8 5. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 6. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 7. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 8. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013ec18ac 9. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013ec09aa 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016b30052 11. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016cdda71 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000130d8a1a 13. /build/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>>&) @ 0x00000000148a05bd 14. /build/src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000001489a16a 15. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 17. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 19. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 20. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 2025.07.13 02:19:30.325330 [ 31788 ] {a7b2217f-386c-4f73-a8fb-339d789aeb63} executeQuery: Code: 44. DB::Exception: Argument at index 2 for function toStartOfInterval must be constant. (ILLEGAL_COLUMN) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57622) (comment: 02916_to_start_of_interval_with_origin.sql) (query 10, line 17) (in query: SELECT toStartOfInterval(toDateTime('2023-01-02 14:45:50'), toIntervalHour(1), materialize(toDateTime('2023-01-02 14:44:30')), 'Europe/Amsterdam');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000b97110b 4. /build/src/Functions/IFunction.cpp:141: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dab8 5. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 6. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 7. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 8. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013ec18ac 9. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013ec09aa 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016b30052 11. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016cdda71 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000130d8a1a 13. /build/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>>&) @ 0x00000000148a05bd 14. /build/src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000001489a16a 15. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 17. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 19. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 20. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 2025.07.13 02:19:30.333497 [ 31788 ] {} TCPHandler: Code: 44. DB::Exception: Argument at index 2 for function toStartOfInterval must be constant. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000b97110b 4. /build/src/Functions/IFunction.cpp:141: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dab8 5. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 6. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 7. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 8. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013ec18ac 9. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013ec09aa 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016b30052 11. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016cdda71 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000130d8a1a 13. /build/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>>&) @ 0x00000000148a05bd 14. /build/src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000001489a16a 15. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 17. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 19. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 20. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 25. ? @ 0x00007f7210eb6ac3 26. ? @ 0x00007f7210f48850 2025.07.13 02:19:30.614867 [ 31788 ] {1a2ee52d-260a-4416-a140-ec7e88df7857} executeQuery: Code: 43. DB::Exception: Illegal type String of 3rd argument of function toStartOfInterval. The third argument must a Date/Date32/DateTime/DateTime64 with a constant origin: In scope SELECT toStartOfInterval(toDateTime('2023-01-02 14:45:50'), toIntervalYear(1), 'Europe/Amsterdam', 'Europe/Amsterdam'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57622) (comment: 02916_to_start_of_interval_with_origin.sql) (query 11, line 19) (in query: -- with 4 arguments, the 3rd one must not be a string or an integer SELECT toStartOfInterval(toDateTime('2023-01-02 14:45:50'), toIntervalYear(1), 'Europe/Amsterdam', 'Europe/Amsterdam');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/toStartOfInterval.cpp:145: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const::'lambda2'()::operator()() const @ 0x000000000e7d1cd5 5. /build/src/Functions/toStartOfInterval.cpp:176: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e79ba67 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:19:30.627479 [ 31788 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of 3rd argument of function toStartOfInterval. The third argument must a Date/Date32/DateTime/DateTime64 with a constant origin: In scope SELECT toStartOfInterval(toDateTime('2023-01-02 14:45:50'), toIntervalYear(1), 'Europe/Amsterdam', 'Europe/Amsterdam'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/toStartOfInterval.cpp:145: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const::'lambda2'()::operator()() const @ 0x000000000e7d1cd5 5. /build/src/Functions/toStartOfInterval.cpp:176: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e79ba67 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:19:31.042415 [ 31788 ] {e6472ce6-948c-44cb-85f2-297770828beb} executeQuery: Code: 43. DB::Exception: Illegal type UInt8 of 3rd argument of function toStartOfInterval. This argument is optional and must be a constant String with timezone name or a Date/Date32/DateTime/DateTime64 with a constant origin: In scope SELECT toStartOfInterval(toDateTime('2023-01-02 14:45:50'), toIntervalYear(1), 5, 'Europe/Amsterdam'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57622) (comment: 02916_to_start_of_interval_with_origin.sql) (query 12, line 21) (in query: SELECT toStartOfInterval(toDateTime('2023-01-02 14:45:50'), toIntervalYear(1), 5, 'Europe/Amsterdam');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/toStartOfInterval.cpp:137: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const::'lambda1'()::operator()() const @ 0x000000000e7d1a45 5. /build/src/Functions/toStartOfInterval.cpp:175: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e79ba5a 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:19:31.053418 [ 31788 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type UInt8 of 3rd argument of function toStartOfInterval. This argument is optional and must be a constant String with timezone name or a Date/Date32/DateTime/DateTime64 with a constant origin: In scope SELECT toStartOfInterval(toDateTime('2023-01-02 14:45:50'), toIntervalYear(1), 5, 'Europe/Amsterdam'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/toStartOfInterval.cpp:137: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const::'lambda1'()::operator()() const @ 0x000000000e7d1a45 5. /build/src/Functions/toStartOfInterval.cpp:175: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e79ba5a 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:19:31.343019 [ 31788 ] {9bfdaa17-7c7e-4cc2-870b-865504c1f0b7} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfInterval doesn't match: passed 5, must be 2, 3 or 4: In scope SELECT toStartOfInterval(toDateTime('2023-01-02 14:45:50'), toIntervalYear(1), toDateTime('2020-01-02 14:44:30'), 'Europe/Amsterdam', 5). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57622) (comment: 02916_to_start_of_interval_with_origin.sql) (query 13, line 23) (in query: -- too many arguments SELECT toStartOfInterval(toDateTime('2023-01-02 14:45:50'), toIntervalYear(1), toDateTime('2020-01-02 14:44:30'), 'Europe/Amsterdam', 5);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000009fb386b 4. /build/src/Functions/toStartOfInterval.cpp:180: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e79bcd1 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:19:31.356442 [ 31788 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfInterval doesn't match: passed 5, must be 2, 3 or 4: In scope SELECT toStartOfInterval(toDateTime('2023-01-02 14:45:50'), toIntervalYear(1), toDateTime('2020-01-02 14:44:30'), 'Europe/Amsterdam', 5). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000009fb386b 4. /build/src/Functions/toStartOfInterval.cpp:180: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e79bcd1 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:19:32.976299 [ 31788 ] {36bd6420-5e36-49b9-885b-e0256e80d078} executeQuery: Code: 43. DB::Exception: Illegal interval kind for argument data type Date: In scope SELECT toStartOfInterval(toDate('2023-10-09'), toIntervalHour(1), toDate('2023-10-09')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57622) (comment: 02916_to_start_of_interval_with_origin.sql) (query 20, line 32) (in query: SELECT toStartOfInterval(toDate('2023-10-09'), toIntervalHour(1), toDate('2023-10-09'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/toStartOfInterval.cpp:312: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e79d147 5. /build/src/Functions/toStartOfInterval.cpp:266: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e79bed9 6. /build/src/Functions/toStartOfInterval.cpp:243: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e79b46f 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 28. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 29. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 2025.07.13 02:19:32.984944 [ 31788 ] {} TCPHandler: Code: 43. DB::Exception: Illegal interval kind for argument data type Date: In scope SELECT toStartOfInterval(toDate('2023-10-09'), toIntervalHour(1), toDate('2023-10-09')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/toStartOfInterval.cpp:312: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e79d147 5. /build/src/Functions/toStartOfInterval.cpp:266: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e79bed9 6. /build/src/Functions/toStartOfInterval.cpp:243: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e79b46f 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 28. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 29. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 2025.07.13 02:19:33.128014 [ 31788 ] {7a8a1f44-8eed-467f-bda4-0da8d487acb6} executeQuery: Code: 43. DB::Exception: Illegal interval kind for argument data type Date: In scope SELECT toStartOfInterval(toDate('2023-10-09'), toIntervalMinute(1), toDate('2023-10-09')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57622) (comment: 02916_to_start_of_interval_with_origin.sql) (query 21, line 33) (in query: SELECT toStartOfInterval(toDate('2023-10-09'), toIntervalMinute(1), toDate('2023-10-09'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/toStartOfInterval.cpp:312: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e79d147 5. /build/src/Functions/toStartOfInterval.cpp:266: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e79bed9 6. /build/src/Functions/toStartOfInterval.cpp:243: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e79b46f 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 28. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 29. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 2025.07.13 02:19:33.134981 [ 31788 ] {} TCPHandler: Code: 43. DB::Exception: Illegal interval kind for argument data type Date: In scope SELECT toStartOfInterval(toDate('2023-10-09'), toIntervalMinute(1), toDate('2023-10-09')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/toStartOfInterval.cpp:312: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e79d147 5. /build/src/Functions/toStartOfInterval.cpp:266: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e79bed9 6. /build/src/Functions/toStartOfInterval.cpp:243: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e79b46f 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 28. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 29. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 2025.07.13 02:19:33.210080 [ 4887 ] {03d60111-08b9-467a-8aa4-c4f4894a2e97} 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]:56244) (comment: 01509_check_parallel_quorum_inserts_long.sh) (query 2, line 3) (in query: CREATE TABLE r1 (`x` UInt64) ENGINE = ReplicatedMergeTree('/clickhouse/tables/01509_check_parallel_quorum_inserts_long_test_mwitgucp/parallel_quorum', 'r1') ORDER BY x SETTINGS index_granularity = 41446, 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 = 536870912, compact_parts_max_bytes_to_buffer = 180271012, compact_parts_max_granules_to_buffer = 109, compact_parts_merge_max_bytes_to_prefetch_part = 13327827, merge_max_block_size = 19182, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 1689798210, vertical_merge_algorithm_min_rows_to_activate = 538340, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 2874616018, index_granularity_bytes = 26389620, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = false, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 43014, primary_key_compress_block_size = 24671, use_primary_key_cache = false, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000013cc1696 5. /build/src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013cc32f5 6. /build/src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc384b 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:19:33.262110 [ 4887 ] {} TCPHandler: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000013cc1696 5. /build/src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013cc32f5 6. /build/src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc384b 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:19:33.277951 [ 31788 ] {ac2ab8ba-37f2-4d0b-8934-86228648efb3} executeQuery: Code: 43. DB::Exception: Illegal interval kind for argument data type Date: In scope SELECT toStartOfInterval(toDate('2023-10-09'), toIntervalSecond(1), toDate('2023-10-09')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57622) (comment: 02916_to_start_of_interval_with_origin.sql) (query 22, line 34) (in query: SELECT toStartOfInterval(toDate('2023-10-09'), toIntervalSecond(1), toDate('2023-10-09'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/toStartOfInterval.cpp:312: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e79d147 5. /build/src/Functions/toStartOfInterval.cpp:266: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e79bed9 6. /build/src/Functions/toStartOfInterval.cpp:243: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e79b46f 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 28. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 29. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 2025.07.13 02:19:33.316415 [ 31788 ] {} TCPHandler: Code: 43. DB::Exception: Illegal interval kind for argument data type Date: In scope SELECT toStartOfInterval(toDate('2023-10-09'), toIntervalSecond(1), toDate('2023-10-09')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/toStartOfInterval.cpp:312: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e79d147 5. /build/src/Functions/toStartOfInterval.cpp:266: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e79bed9 6. /build/src/Functions/toStartOfInterval.cpp:243: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e79b46f 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 28. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 29. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 2025.07.13 02:19:33.659961 [ 31788 ] {1529207c-1f84-42fd-ac7e-79b5d6dffacb} executeQuery: Code: 43. DB::Exception: Illegal interval kind for argument data type Date: In scope SELECT toStartOfInterval(toDate('2023-10-09'), toIntervalMillisecond(1), toDate('2023-10-09')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57622) (comment: 02916_to_start_of_interval_with_origin.sql) (query 23, line 35) (in query: SELECT toStartOfInterval(toDate('2023-10-09'), toIntervalMillisecond(1), toDate('2023-10-09'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000c70ce0b 4. /build/src/Functions/toStartOfInterval.cpp:306: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e79cbea 5. /build/src/Functions/toStartOfInterval.cpp:266: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e79bed9 6. /build/src/Functions/toStartOfInterval.cpp:243: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e79b46f 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 28. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 29. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 2025.07.13 02:19:33.679588 [ 31788 ] {} TCPHandler: Code: 43. DB::Exception: Illegal interval kind for argument data type Date: In scope SELECT toStartOfInterval(toDate('2023-10-09'), toIntervalMillisecond(1), toDate('2023-10-09')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000c70ce0b 4. /build/src/Functions/toStartOfInterval.cpp:306: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e79cbea 5. /build/src/Functions/toStartOfInterval.cpp:266: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e79bed9 6. /build/src/Functions/toStartOfInterval.cpp:243: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e79b46f 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 28. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 29. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 2025.07.13 02:19:33.778089 [ 12989 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:19:33.787214 [ 31788 ] {bcf3c7a9-8a56-4b3f-a246-15be47585a3e} executeQuery: Code: 43. DB::Exception: Illegal interval kind for argument data type Date: In scope SELECT toStartOfInterval(toDate('2023-10-09'), toIntervalMicrosecond(1), toDate('2023-10-09')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57622) (comment: 02916_to_start_of_interval_with_origin.sql) (query 24, line 36) (in query: SELECT toStartOfInterval(toDate('2023-10-09'), toIntervalMicrosecond(1), toDate('2023-10-09'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000c70ce0b 4. /build/src/Functions/toStartOfInterval.cpp:306: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e79cbea 5. /build/src/Functions/toStartOfInterval.cpp:266: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e79bed9 6. /build/src/Functions/toStartOfInterval.cpp:243: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e79b46f 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 28. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 29. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 2025.07.13 02:19:33.798635 [ 31788 ] {} TCPHandler: Code: 43. DB::Exception: Illegal interval kind for argument data type Date: In scope SELECT toStartOfInterval(toDate('2023-10-09'), toIntervalMicrosecond(1), toDate('2023-10-09')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000c70ce0b 4. /build/src/Functions/toStartOfInterval.cpp:306: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e79cbea 5. /build/src/Functions/toStartOfInterval.cpp:266: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e79bed9 6. /build/src/Functions/toStartOfInterval.cpp:243: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e79b46f 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 28. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 29. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 2025.07.13 02:19:33.843730 [ 30860 ] {} TCPHandler: Code: 394. DB::Exception: Query 'efc26d27-2095-4bef-82c7-6a913850c6ef' is killed in pending state. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Interpreters/executeQuery.cpp:1522: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba846f 5. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 6. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 7. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 12. ? @ 0x00007f7210eb6ac3 13. ? @ 0x00007f7210f48850 2025.07.13 02:19:34.070965 [ 31788 ] {74709a8c-7125-4787-998f-f61dbb86309c} executeQuery: Code: 43. DB::Exception: Illegal interval kind for argument data type Date: In scope SELECT toStartOfInterval(toDate('2023-10-09'), toIntervalNanosecond(1), toDate('2023-10-09')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57622) (comment: 02916_to_start_of_interval_with_origin.sql) (query 25, line 37) (in query: SELECT toStartOfInterval(toDate('2023-10-09'), toIntervalNanosecond(1), toDate('2023-10-09'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000c70ce0b 4. /build/src/Functions/toStartOfInterval.cpp:306: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e79cbea 5. /build/src/Functions/toStartOfInterval.cpp:266: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e79bed9 6. /build/src/Functions/toStartOfInterval.cpp:243: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e79b46f 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 28. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 29. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 2025.07.13 02:19:34.078697 [ 31788 ] {} TCPHandler: Code: 43. DB::Exception: Illegal interval kind for argument data type Date: In scope SELECT toStartOfInterval(toDate('2023-10-09'), toIntervalNanosecond(1), toDate('2023-10-09')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000c70ce0b 4. /build/src/Functions/toStartOfInterval.cpp:306: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e79cbea 5. /build/src/Functions/toStartOfInterval.cpp:266: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e79bed9 6. /build/src/Functions/toStartOfInterval.cpp:243: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e79b46f 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 28. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 29. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 2025.07.13 02:19:34.623713 [ 47971 ] {d09231d7-1302-4007-9122-969081871d5e} ExternalDictionariesLoader: Could not load external dictionary '0ca1414e-e1b1-4e07-bc23-aa654781fa7d', next update is scheduled at 2025-07-13 02:19:40: Code: 36. DB::Exception: 0ca1414e-e1b1-4e07-bc23-aa654781fa7d: SHARDS parameter does not supports for updatable source (UPDATE_FIELD). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Dictionaries/registerHashedDictionary.cpp:89: DB::registerDictionaryHashed(DB::DictionaryFactory&)::$_4::operator()(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, DB::DictionaryKeyType, bool) const @ 0x0000000011c50410 5. /build/src/Dictionaries/registerHashedDictionary.cpp:127: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:se190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x0000000011c509d9 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012c74f5d 7. /build/src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000147cade4 8. /build/src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000147d6c48 9. /build/src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000147d56dd 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000147d96f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000147d64cd 5. /build/src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000147d465c 6. /build/src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x00000000147e47a8 7. /build/contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&) @ 0x00000000147e445c 8. /build/src/Interpreters/ExternalLoader.cpp:623: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoadOrReload(String const&, std::chrono::duration>) @ 0x00000000147d2c42 9. /build/src/Interpreters/ExternalLoader.cpp:1397: std::shared_ptr DB::ExternalLoader::loadOrReload, void>(String const&) const @ 0x00000000147d10e9 10. /build/src/Interpreters/ExternalDictionariesLoader.cpp:108: DB::ExternalDictionariesLoader::reloadDictionary(String const&, std::shared_ptr) const @ 0x00000000147cbd88 11. /build/src/Interpreters/InterpreterSystemQuery.cpp:613: DB::InterpreterSystemQuery::execute() @ 0x0000000014bd5c5d 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 14. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 15. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 20. ? @ 0x00007f7210eb6ac3 21. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:19:34.644137 [ 4922 ] {d09231d7-1302-4007-9122-969081871d5e} executeQuery: Code: 36. DB::Exception: 0ca1414e-e1b1-4e07-bc23-aa654781fa7d: SHARDS parameter does not supports for updatable source (UPDATE_FIELD). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36928) (comment: 02391_hashed_dictionary_shards.sql) (query 36, line 106) (in query: SYSTEM RELOAD DICTIONARY test_dictionary_10_shards_incremental;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Dictionaries/registerHashedDictionary.cpp:89: DB::registerDictionaryHashed(DB::DictionaryFactory&)::$_4::operator()(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, DB::DictionaryKeyType, bool) const @ 0x0000000011c50410 5. /build/src/Dictionaries/registerHashedDictionary.cpp:127: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:se190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x0000000011c509d9 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012c74f5d 7. /build/src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000147cade4 8. /build/src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000147d6c48 9. /build/src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000147d56dd 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000147d96f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:19:34.659708 [ 4922 ] {} TCPHandler: Code: 36. DB::Exception: 0ca1414e-e1b1-4e07-bc23-aa654781fa7d: SHARDS parameter does not supports for updatable source (UPDATE_FIELD). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Dictionaries/registerHashedDictionary.cpp:89: DB::registerDictionaryHashed(DB::DictionaryFactory&)::$_4::operator()(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, DB::DictionaryKeyType, bool) const @ 0x0000000011c50410 5. /build/src/Dictionaries/registerHashedDictionary.cpp:127: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:se190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x0000000011c509d9 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012c74f5d 7. /build/src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000147cade4 8. /build/src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000147d6c48 9. /build/src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000147d56dd 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000147d96f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000147d64cd 5. /build/src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000147d465c 6. /build/src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x00000000147e47a8 7. /build/contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&) @ 0x00000000147e445c 8. /build/src/Interpreters/ExternalLoader.cpp:623: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoadOrReload(String const&, std::chrono::duration>) @ 0x00000000147d2c42 9. /build/src/Interpreters/ExternalLoader.cpp:1397: std::shared_ptr DB::ExternalLoader::loadOrReload, void>(String const&) const @ 0x00000000147d10e9 10. /build/src/Interpreters/ExternalDictionariesLoader.cpp:108: DB::ExternalDictionariesLoader::reloadDictionary(String const&, std::shared_ptr) const @ 0x00000000147cbd88 11. /build/src/Interpreters/InterpreterSystemQuery.cpp:613: DB::InterpreterSystemQuery::execute() @ 0x0000000014bd5c5d 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 14. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 15. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 20. ? @ 0x00007f7210eb6ac3 21. ? @ 0x00007f7210f48850 2025.07.13 02:19:34.953945 [ 16758 ] {1052027729} 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]:56256) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 9. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:19:35.176437 [ 16758 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 9. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:19:35.394936 [ 4922 ] {d6d93302-bf04-4634-aa95-1efbd3c762f1} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02391_hashed_dictionary_shards.sql) (in query: /* ddl_entry=query-0000000158 */ TRUNCATE DICTIONARY test_5.test_dictionary_10_shards_incremental), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833ede 5. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 7. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 9. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 10. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 11. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 12. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 13. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 14. /build/src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833287 15. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 16. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 17. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 18. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:19:35.478743 [ 4922 ] {d6d93302-bf04-4634-aa95-1efbd3c762f1} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36928) (comment: 02391_hashed_dictionary_shards.sql) (query 37, line 108) (in query: DROP DICTIONARY test_dictionary_10_shards_incremental;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833ede 5. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 7. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 9. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 10. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 11. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 12. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 13. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 14. /build/src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833287 15. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 16. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 17. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 18. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:19:35.499836 [ 4922 ] {} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833ede 5. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 7. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 9. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 10. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 11. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 12. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 13. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 14. /build/src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014833287 15. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000014831af4 16. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831247 17. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 18. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 20. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 21. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 26. ? @ 0x00007f7210eb6ac3 27. ? @ 0x00007f7210f48850 2025.07.13 02:19:35.513269 [ 3775 ] {} DNSResolver: Cannot resolve host (localhos), error 0: Host not found. 2025.07.13 02:19:35.990886 [ 31788 ] {df310ac4-791c-45a5-80d1-25e0d6779839} executeQuery: Code: 43. DB::Exception: Illegal interval kind for argument data type Date: In scope SELECT toStartOfInterval(toDate32('2023-10-09'), toIntervalHour(1), toDate32('2023-10-09')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57622) (comment: 02916_to_start_of_interval_with_origin.sql) (query 32, line 45) (in query: SELECT toStartOfInterval(toDate32('2023-10-09'), toIntervalHour(1), toDate32('2023-10-09'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/toStartOfInterval.cpp:312: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate32 const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e7ab947 5. /build/src/Functions/toStartOfInterval.cpp:272: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e79c279 6. /build/src/Functions/toStartOfInterval.cpp:245: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e79b4d4 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 28. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 29. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 2025.07.13 02:19:36.006576 [ 31788 ] {} TCPHandler: Code: 43. DB::Exception: Illegal interval kind for argument data type Date: In scope SELECT toStartOfInterval(toDate32('2023-10-09'), toIntervalHour(1), toDate32('2023-10-09')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/toStartOfInterval.cpp:312: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate32 const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e7ab947 5. /build/src/Functions/toStartOfInterval.cpp:272: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e79c279 6. /build/src/Functions/toStartOfInterval.cpp:245: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e79b4d4 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 28. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 29. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 2025.07.13 02:19:36.070773 [ 37313 ] {de39efde-b848-40cf-9c9a-b3f085b17794} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 16.00, current rows: 2.05 thousand. (TOO_MANY_ROWS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57452) (comment: 00990_hasToken_and_tokenbf.sql) (query 30, line 51) (in query: -- invert result -- this does not work as expected, reading more rows that it should -- SELECT max(id) FROM bloom_filter WHERE NOT hasToken(s, 'yyy'); -- accessing to many rows SELECT max(id) FROM bloom_filter WHERE hasToken(s, 'yyy');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000013af9d2b 4. /build/src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013af96d2 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x0000000016d41675 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d56e9c 7. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016cf6870 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:19:36.145611 [ 37313 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 16.00, current rows: 2.05 thousand. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000013af9d2b 4. /build/src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013af96d2 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x0000000016d41675 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d56e9c 7. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016cf6870 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:19:36.253003 [ 31788 ] {3d72f34a-4e89-4a11-a558-9124547c8d78} executeQuery: Code: 43. DB::Exception: Illegal interval kind for argument data type Date: In scope SELECT toStartOfInterval(toDate32('2023-10-09'), toIntervalMinute(1), toDate32('2023-10-09')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57622) (comment: 02916_to_start_of_interval_with_origin.sql) (query 33, line 46) (in query: SELECT toStartOfInterval(toDate32('2023-10-09'), toIntervalMinute(1), toDate32('2023-10-09'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/toStartOfInterval.cpp:312: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate32 const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e7ab947 5. /build/src/Functions/toStartOfInterval.cpp:272: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e79c279 6. /build/src/Functions/toStartOfInterval.cpp:245: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e79b4d4 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 28. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 29. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 2025.07.13 02:19:36.267373 [ 31788 ] {} TCPHandler: Code: 43. DB::Exception: Illegal interval kind for argument data type Date: In scope SELECT toStartOfInterval(toDate32('2023-10-09'), toIntervalMinute(1), toDate32('2023-10-09')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/toStartOfInterval.cpp:312: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate32 const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e7ab947 5. /build/src/Functions/toStartOfInterval.cpp:272: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e79c279 6. /build/src/Functions/toStartOfInterval.cpp:245: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e79b4d4 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 28. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 29. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 2025.07.13 02:19:36.402864 [ 31788 ] {7b7db198-89a8-4119-ad94-78dd5d953ba3} executeQuery: Code: 43. DB::Exception: Illegal interval kind for argument data type Date: In scope SELECT toStartOfInterval(toDate32('2023-10-09'), toIntervalSecond(1), toDate32('2023-10-09')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57622) (comment: 02916_to_start_of_interval_with_origin.sql) (query 34, line 47) (in query: SELECT toStartOfInterval(toDate32('2023-10-09'), toIntervalSecond(1), toDate32('2023-10-09'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/toStartOfInterval.cpp:312: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate32 const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e7ab947 5. /build/src/Functions/toStartOfInterval.cpp:272: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e79c279 6. /build/src/Functions/toStartOfInterval.cpp:245: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e79b4d4 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 28. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 29. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 2025.07.13 02:19:36.500935 [ 37313 ] {7f432d89-0122-4583-ab81-068369049c3f} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 16.00, current rows: 3.08 thousand. (TOO_MANY_ROWS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57452) (comment: 00990_hasToken_and_tokenbf.sql) (query 31, line 58) (in query: -- this syntax is not supported by tokenbf SELECT max(id) FROM bloom_filter WHERE hasToken(s, 'zzz') == 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000013af9d2b 4. /build/src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013af96d2 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x0000000016d41675 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d56e9c 7. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016cf6870 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:19:36.506970 [ 31788 ] {} TCPHandler: Code: 43. DB::Exception: Illegal interval kind for argument data type Date: In scope SELECT toStartOfInterval(toDate32('2023-10-09'), toIntervalSecond(1), toDate32('2023-10-09')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Functions/toStartOfInterval.cpp:312: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate32 const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e7ab947 5. /build/src/Functions/toStartOfInterval.cpp:272: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e79c279 6. /build/src/Functions/toStartOfInterval.cpp:245: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e79b4d4 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 28. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 29. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 2025.07.13 02:19:36.519531 [ 37313 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 16.00, current rows: 3.08 thousand. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000013af9d2b 4. /build/src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013af96d2 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x0000000016d41675 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d56e9c 7. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016cf6870 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:19:36.711312 [ 31788 ] {9cf11bee-2532-461e-acf8-6f2e0183c551} executeQuery: Code: 43. DB::Exception: Illegal interval kind for argument data type DateTime: In scope SELECT toStartOfInterval(toDate32('2023-10-09'), toIntervalMillisecond(1), toDate32('2023-10-09')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57622) (comment: 02916_to_start_of_interval_with_origin.sql) (query 35, line 48) (in query: SELECT toStartOfInterval(toDate32('2023-10-09'), toIntervalMillisecond(1), toDate32('2023-10-09'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000c70ce0b 4. /build/src/Functions/toStartOfInterval.cpp:306: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate32 const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e7ab3ea 5. /build/src/Functions/toStartOfInterval.cpp:272: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e79c279 6. /build/src/Functions/toStartOfInterval.cpp:245: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e79b4d4 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 28. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 29. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 2025.07.13 02:19:36.732468 [ 31788 ] {} TCPHandler: Code: 43. DB::Exception: Illegal interval kind for argument data type DateTime: In scope SELECT toStartOfInterval(toDate32('2023-10-09'), toIntervalMillisecond(1), toDate32('2023-10-09')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000c70ce0b 4. /build/src/Functions/toStartOfInterval.cpp:306: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate32 const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e7ab3ea 5. /build/src/Functions/toStartOfInterval.cpp:272: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e79c279 6. /build/src/Functions/toStartOfInterval.cpp:245: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e79b4d4 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 28. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 29. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 2025.07.13 02:19:36.882138 [ 16758 ] {186579381} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=17, jobs=2): While reading or decompressing /var/lib/clickhouse/store/719/71971bbb-f40a-4b2d-a752-59eed97c8cea/all_1_9_2/d.bin (position: 5526487, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: b66b7cec55fb54e78664ed753b8924e9820b01010000000100): (while reading column d): (while reading from part /var/lib/clickhouse/store/719/71971bbb-f40a-4b2d-a752-59eed97c8cea/all_1_9_2/ in table test_9.t (71971bbb-f40a-4b2d-a752-59eed97c8cea) located on disk default of type local, from mark 166 with max_rows_to_read = 43): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56274) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x00000000130ebd1a 8. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:se190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x00000000130ebb0f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130eacce 10. /build/src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000130e21d0 11. /build/src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000130e24cb 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 13. /build/src/IO/ReadBuffer.h:96: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000fb79357 14. /build/src/Compression/CompressedReadBufferBase.cpp:209: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000017858d7c 15. /build/src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000001785bd1c 16. /build/src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000013bfbf7f 17. /build/src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000013ba04c3 18. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x00000000163ce98e 19. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000163ce0d2 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000163bc9b1 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::continueReadingChain(DB::MergeTreeRangeReader::ReadResult&, unsigned long&) @ 0x00000000163c47df 22. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:81: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x00000000163def61 23. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x00000000163dace0 24. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x0000000016d617ec 25. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5584 26. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 27. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 28. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 29. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 30. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 31. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 2025.07.13 02:19:36.887638 [ 31788 ] {1fa82ad7-2810-4a49-8920-41308f754b0c} executeQuery: Code: 43. DB::Exception: Illegal interval kind for argument data type DateTime: In scope SELECT toStartOfInterval(toDate32('2023-10-09'), toIntervalMicrosecond(1), toDate32('2023-10-09')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57622) (comment: 02916_to_start_of_interval_with_origin.sql) (query 36, line 49) (in query: SELECT toStartOfInterval(toDate32('2023-10-09'), toIntervalMicrosecond(1), toDate32('2023-10-09'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000c70ce0b 4. /build/src/Functions/toStartOfInterval.cpp:306: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate32 const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e7ab3ea 5. /build/src/Functions/toStartOfInterval.cpp:272: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e79c279 6. /build/src/Functions/toStartOfInterval.cpp:245: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e79b4d4 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 28. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 29. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 2025.07.13 02:19:36.945516 [ 16763 ] {62a5cfc9-35be-4ce2-a500-1eac5efbbbc7} 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]:38118) (comment: 00804_test_delta_codec_no_type_alter.sql) (in query: DROP DATABASE IF EXISTS test_ofm1qxpa SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:19:37.011212 [ 37313 ] {17640a48-d584-4e00-a014-5ae612f921df} executeQuery: Code: 57. DB::Exception: Table test_13.tab already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57452) (comment: 00990_hasToken_and_tokenbf.sql) (query 33, line 63) (in query: CREATE TABLE tab (`row_id` UInt32, `str` String, INDEX idx str TYPE tokenbf_v1(256, 2, 0) GRANULARITY 1) ENGINE = MergeTree ORDER BY row_id SETTINGS index_granularity = 18619, min_bytes_for_wide_part = 360906676, ratio_of_defaults_for_sparse_serialization = 0.14005061984062195, 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 = 462094703, compact_parts_max_granules_to_buffer = 60, compact_parts_merge_max_bytes_to_prefetch_part = 31043067, merge_max_block_size = 10388, old_parts_lifetime = 195., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 209270, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 7155932608, index_granularity_bytes = 940210, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 25, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 54324, primary_key_compress_block_size = 47388, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:19:37.011636 [ 31788 ] {} TCPHandler: Code: 43. DB::Exception: Illegal interval kind for argument data type DateTime: In scope SELECT toStartOfInterval(toDate32('2023-10-09'), toIntervalMicrosecond(1), toDate32('2023-10-09')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000c70ce0b 4. /build/src/Functions/toStartOfInterval.cpp:306: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate32 const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e7ab3ea 5. /build/src/Functions/toStartOfInterval.cpp:272: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e79c279 6. /build/src/Functions/toStartOfInterval.cpp:245: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e79b4d4 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 28. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 29. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 2025.07.13 02:19:37.013108 [ 16763 ] {62a5cfc9-35be-4ce2-a500-1eac5efbbbc7} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:19:37.035490 [ 37313 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:19:37.118396 [ 31788 ] {d851b2b6-cb72-468d-a52d-85f9df0b880f} executeQuery: Code: 43. DB::Exception: Illegal interval kind for argument data type DateTime: In scope SELECT toStartOfInterval(toDate32('2023-10-09'), toIntervalNanosecond(1), toDate32('2023-10-09')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57622) (comment: 02916_to_start_of_interval_with_origin.sql) (query 37, line 50) (in query: SELECT toStartOfInterval(toDate32('2023-10-09'), toIntervalNanosecond(1), toDate32('2023-10-09'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000c70ce0b 4. /build/src/Functions/toStartOfInterval.cpp:306: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate32 const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e7ab3ea 5. /build/src/Functions/toStartOfInterval.cpp:272: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e79c279 6. /build/src/Functions/toStartOfInterval.cpp:245: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e79b4d4 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 28. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 29. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 2025.07.13 02:19:37.161932 [ 31788 ] {} TCPHandler: Code: 43. DB::Exception: Illegal interval kind for argument data type DateTime: In scope SELECT toStartOfInterval(toDate32('2023-10-09'), toIntervalNanosecond(1), toDate32('2023-10-09')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000c70ce0b 4. /build/src/Functions/toStartOfInterval.cpp:306: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate32 const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e7ab3ea 5. /build/src/Functions/toStartOfInterval.cpp:272: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e79c279 6. /build/src/Functions/toStartOfInterval.cpp:245: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e79b4d4 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 28. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 29. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 2025.07.13 02:19:37.268026 [ 16758 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=17, jobs=2): While reading or decompressing /var/lib/clickhouse/store/719/71971bbb-f40a-4b2d-a752-59eed97c8cea/all_1_9_2/d.bin (position: 5526487, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: b66b7cec55fb54e78664ed753b8924e9820b01010000000100): (while reading column d): (while reading from part /var/lib/clickhouse/store/719/71971bbb-f40a-4b2d-a752-59eed97c8cea/all_1_9_2/ in table test_9.t (71971bbb-f40a-4b2d-a752-59eed97c8cea) located on disk default of type local, from mark 166 with max_rows_to_read = 43): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x00000000130ebd1a 8. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:se190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x00000000130ebb0f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130eacce 10. /build/src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000130e21d0 11. /build/src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000130e24cb 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a08ccfb 13. /build/src/IO/ReadBuffer.h:96: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000fb79357 14. /build/src/Compression/CompressedReadBufferBase.cpp:209: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000017858d7c 15. /build/src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000001785bd1c 16. /build/src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000013bfbf7f 17. /build/src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000013ba04c3 18. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x00000000163ce98e 19. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000163ce0d2 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000163bc9b1 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::continueReadingChain(DB::MergeTreeRangeReader::ReadResult&, unsigned long&) @ 0x00000000163c47df 22. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:81: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x00000000163def61 23. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x00000000163dace0 24. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x0000000016d617ec 25. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5584 26. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 27. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 28. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 29. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 30. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 31. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:19:38.942354 [ 40061 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:19:39.880427 [ 32568 ] {} TCPHandler: Code: 394. DB::Exception: Query '4ea7963e-04c1-4457-aac5-5d5319cbbd2d' is killed in pending state. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Interpreters/executeQuery.cpp:1522: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba846f 5. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 6. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 7. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 12. ? @ 0x00007f7210eb6ac3 13. ? @ 0x00007f7210f48850 2025.07.13 02:19:40.173902 [ 31788 ] {b10cd5c6-6077-42b5-a55b-ffc61faff5bf} executeQuery: Code: 43. DB::Exception: Illegal interval kind for argument data type DateTime: In scope SELECT toStartOfInterval(toDateTime('2023-10-09 10:11:12'), toIntervalMillisecond(1), toDateTime('2023-10-09 10:11:12')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57622) (comment: 02916_to_start_of_interval_with_origin.sql) (query 47, line 61) (in query: SELECT toStartOfInterval(toDateTime('2023-10-09 10:11:12'), toIntervalMillisecond(1), toDateTime('2023-10-09 10:11:12'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000c70ce0b 4. /build/src/Functions/toStartOfInterval.cpp:306: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDateTime const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e7b842a 5. /build/src/Functions/toStartOfInterval.cpp:278: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e79c619 6. /build/src/Functions/toStartOfInterval.cpp:247: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e79b587 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 28. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 29. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 2025.07.13 02:19:40.201365 [ 31788 ] {} TCPHandler: Code: 43. DB::Exception: Illegal interval kind for argument data type DateTime: In scope SELECT toStartOfInterval(toDateTime('2023-10-09 10:11:12'), toIntervalMillisecond(1), toDateTime('2023-10-09 10:11:12')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000c70ce0b 4. /build/src/Functions/toStartOfInterval.cpp:306: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDateTime const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e7b842a 5. /build/src/Functions/toStartOfInterval.cpp:278: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e79c619 6. /build/src/Functions/toStartOfInterval.cpp:247: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e79b587 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 28. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 29. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 2025.07.13 02:19:40.323352 [ 31788 ] {0cd001b7-abb2-4e7d-af48-db5dfaa18dd7} executeQuery: Code: 43. DB::Exception: Illegal interval kind for argument data type DateTime: In scope SELECT toStartOfInterval(toDateTime('2023-10-09 10:11:12'), toIntervalMicrosecond(1), toDateTime('2023-10-09 10:11:12')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57622) (comment: 02916_to_start_of_interval_with_origin.sql) (query 48, line 62) (in query: SELECT toStartOfInterval(toDateTime('2023-10-09 10:11:12'), toIntervalMicrosecond(1), toDateTime('2023-10-09 10:11:12'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000c70ce0b 4. /build/src/Functions/toStartOfInterval.cpp:306: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDateTime const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e7b842a 5. /build/src/Functions/toStartOfInterval.cpp:278: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e79c619 6. /build/src/Functions/toStartOfInterval.cpp:247: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e79b587 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 28. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 29. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 2025.07.13 02:19:40.339871 [ 31788 ] {} TCPHandler: Code: 43. DB::Exception: Illegal interval kind for argument data type DateTime: In scope SELECT toStartOfInterval(toDateTime('2023-10-09 10:11:12'), toIntervalMicrosecond(1), toDateTime('2023-10-09 10:11:12')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000c70ce0b 4. /build/src/Functions/toStartOfInterval.cpp:306: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDateTime const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e7b842a 5. /build/src/Functions/toStartOfInterval.cpp:278: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e79c619 6. /build/src/Functions/toStartOfInterval.cpp:247: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e79b587 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 28. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 29. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 2025.07.13 02:19:40.620067 [ 31788 ] {0cd700bf-e4b1-4feb-9e56-a55a42971f78} executeQuery: Code: 43. DB::Exception: Illegal interval kind for argument data type DateTime: In scope SELECT toStartOfInterval(toDateTime('2023-10-09 10:11:12'), toIntervalNanosecond(1), toDateTime('2023-10-09 10:11:12')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:57622) (comment: 02916_to_start_of_interval_with_origin.sql) (query 49, line 63) (in query: SELECT toStartOfInterval(toDateTime('2023-10-09 10:11:12'), toIntervalNanosecond(1), toDateTime('2023-10-09 10:11:12'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000c70ce0b 4. /build/src/Functions/toStartOfInterval.cpp:306: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDateTime const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e7b842a 5. /build/src/Functions/toStartOfInterval.cpp:278: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e79c619 6. /build/src/Functions/toStartOfInterval.cpp:247: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e79b587 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 28. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 29. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 2025.07.13 02:19:40.634517 [ 31788 ] {} TCPHandler: Code: 43. DB::Exception: Illegal interval kind for argument data type DateTime: In scope SELECT toStartOfInterval(toDateTime('2023-10-09 10:11:12'), toIntervalNanosecond(1), toDateTime('2023-10-09 10:11:12')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000c70ce0b 4. /build/src/Functions/toStartOfInterval.cpp:306: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDateTime const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e7b842a 5. /build/src/Functions/toStartOfInterval.cpp:278: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e79c619 6. /build/src/Functions/toStartOfInterval.cpp:247: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e79b587 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 28. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 29. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 2025.07.13 02:19:41.725033 [ 6619 ] {71b39f67-3250-4ec8-a3ef-c9c97e76220a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=900, jobs=842). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56310) (comment: 01513_defaults_on_defaults_no_column.sql) (query 12, line 26) (in query: SELECT 1 from defaults_on_defaults where ArrLen = 0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbdd1d3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd751c 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 9. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 10. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:19:41.763848 [ 6619 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=900, jobs=842). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbdd1d3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd751c 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 9. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 10. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 11. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 2025.07.13 02:19:44.113387 [ 47986 ] {} ExternalDictionariesLoader: Could not load external dictionary '0ca1414e-e1b1-4e07-bc23-aa654781fa7d', next update is scheduled at 2025-07-13 02:19:50: Code: 36. DB::Exception: 0ca1414e-e1b1-4e07-bc23-aa654781fa7d: SHARDS parameter does not supports for updatable source (UPDATE_FIELD). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Dictionaries/registerHashedDictionary.cpp:89: DB::registerDictionaryHashed(DB::DictionaryFactory&)::$_4::operator()(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, DB::DictionaryKeyType, bool) const @ 0x0000000011c50410 5. /build/src/Dictionaries/registerHashedDictionary.cpp:127: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:se190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x0000000011c509d9 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012c74f5d 7. /build/src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000147cade4 8. /build/src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000147d6c48 9. /build/src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000147d56dd 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000147d96f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:19:44.250809 [ 47968 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:19:47.007639 [ 4888 ] {7118fb68-566c-470a-b2da-4a27597c30b4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=29, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56572) (comment: 00945_bloom_filter_index.sql) (query 66, line 85) (in query: SELECT COUNT() FROM bloom_filter_array_types_test WHERE has(fixed_string, toFixedString('1', 5));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x00000000163993d1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016396620 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001639641f 10. /build/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) @ 0x0000000016348ab5 11. /build/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) @ 0x0000000016320893 12. /build/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 @ 0x000000001631d72c 13. /build/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) @ 0x000000001631aaab 14. /build/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) @ 0x0000000016d5067d 15. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x0000000016d4f5b9 16. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x0000000016d4f3b2 17. /build/src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:612: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x0000000016df9dfe 18. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:196: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1c92 19. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 22. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:19:47.043754 [ 4888 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=29, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x00000000163993d1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016396620 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001639641f 10. /build/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) @ 0x0000000016348ab5 11. /build/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) @ 0x0000000016320893 12. /build/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 @ 0x000000001631d72c 13. /build/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) @ 0x000000001631aaab 14. /build/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) @ 0x0000000016d5067d 15. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x0000000016d4f5b9 16. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x0000000016d4f3b2 17. /build/src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:612: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x0000000016df9dfe 18. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:196: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016dd1c92 19. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25c5c 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 22. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:19:47.463434 [ 4268 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {dc8779e6-38bb-45b3-9b02-02231f09e3dc::202507_1_185_37}: Code: 241. DB::Exception: Thread memory tracker: fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000000fb2dc4b 4. /build/src/Common/MemoryTracker.cpp:196: MemoryTracker::injectFault() const @ 0x000000000fb2b6cd 5. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:153: DB::MergePlainMergeTreeTask::finish() @ 0x0000000016593639 6. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:72: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000016592af2 7. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 8. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:19:49.014949 [ 47969 ] {} ExternalDictionariesLoader: Could not load external dictionary '02ea2b3a-7cb3-4b74-abb1-4f80305a92a9', next update is scheduled at 2025-07-13 02:20:03: Code: 482. DB::Exception: Dictionaries with executable dictionary source are not allowed to be created from DDL query. (DICTIONARY_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Dictionaries/ExecutableDictionarySource.cpp:233: std::shared_ptr std::__function::__policy_invoker (DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr, String const&, bool)>::__call_impl[abi:se190107] (DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr, String const&, bool)>>(std::__function::__policy_storage const*, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr&&, String const&, bool) @ 0x00000000119c8c6b 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012c76e33 6. /build/src/Dictionaries/DictionaryFactory.cpp:47: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x0000000012c74a2d 7. /build/src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000147cade4 8. /build/src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000147d6c48 9. /build/src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000147d56dd 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000147d96f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:19:49.246939 [ 12987 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:19:50.208150 [ 37319 ] {e541d7ec-13a4-457e-977c-47ea49b72553} executeQuery: Code: 643. DB::Exception: Couldn't open archive '/var/lib/clickhouse/user_files/02994_file_1752365978/test.rar.7z': Unrecognized archive format: The table structure cannot be extracted from a CSV format file. You can specify the structure manually. (CANNOT_UNPACK_ARCHIVE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35726) (comment: 02994_libarchive_compression.sh) (query 1, line 1) (in query: SELECT c1 FROM file('02994_file_1752365978/test.rar.7z :: test.csv', CSV);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, char const*&&) @ 0x000000001174aacb 4. /build/src/IO/Archives/LibArchiveReader.cpp:240: DB::LibArchiveReader::Handle::openWithPath(String const&) @ 0x000000001324d74f 5. /build/src/IO/Archives/LibArchiveReader.cpp:43: DB::LibArchiveReader::Handle::Handle(String, bool) @ 0x000000001324c6ba 6. /build/src/IO/Archives/LibArchiveReader.cpp:485: DB::LibArchiveReader::acquireHandle() @ 0x000000001324a648 7. /build/src/IO/Archives/LibArchiveReader.cpp:405: DB::LibArchiveReader::readFile(String const&, bool) @ 0x000000001324ab07 8. /build/src/Storages/StorageFile.cpp:702: DB::(anonymous namespace)::ReadBufferFromArchiveIterator::next() @ 0x0000000015cb48f5 9. /build/src/Formats/ReadSchemaUtils.cpp:152: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x0000000016896ec7 10. /build/src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001689af42 11. /build/src/Storages/StorageFile.cpp:978: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x0000000015ca6741 12. /build/src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x0000000015ca6f9c 13. /build/src/Storages/StorageFile.cpp:1122: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x0000000015ca7e12 14. /build/src/Storages/StorageFile.cpp:1063: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x0000000015ca95f9 15. /build/src/Storages/StorageFile.cpp:1067: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x0000000015ca9c5c 16. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], String const&, String, bool, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x00000000117228aa 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x0000000011720b78 18. /build/src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000011723a7c 19. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000130d4903 20. /build/src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000143537f2 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3da49 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 25. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 26. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 31. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 2025.07.13 02:19:50.279904 [ 37319 ] {} TCPHandler: Code: 643. DB::Exception: Couldn't open archive '/var/lib/clickhouse/user_files/02994_file_1752365978/test.rar.7z': Unrecognized archive format: The table structure cannot be extracted from a CSV format file. You can specify the structure manually. (CANNOT_UNPACK_ARCHIVE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, char const*&&) @ 0x000000001174aacb 4. /build/src/IO/Archives/LibArchiveReader.cpp:240: DB::LibArchiveReader::Handle::openWithPath(String const&) @ 0x000000001324d74f 5. /build/src/IO/Archives/LibArchiveReader.cpp:43: DB::LibArchiveReader::Handle::Handle(String, bool) @ 0x000000001324c6ba 6. /build/src/IO/Archives/LibArchiveReader.cpp:485: DB::LibArchiveReader::acquireHandle() @ 0x000000001324a648 7. /build/src/IO/Archives/LibArchiveReader.cpp:405: DB::LibArchiveReader::readFile(String const&, bool) @ 0x000000001324ab07 8. /build/src/Storages/StorageFile.cpp:702: DB::(anonymous namespace)::ReadBufferFromArchiveIterator::next() @ 0x0000000015cb48f5 9. /build/src/Formats/ReadSchemaUtils.cpp:152: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x0000000016896ec7 10. /build/src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001689af42 11. /build/src/Storages/StorageFile.cpp:978: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x0000000015ca6741 12. /build/src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x0000000015ca6f9c 13. /build/src/Storages/StorageFile.cpp:1122: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x0000000015ca7e12 14. /build/src/Storages/StorageFile.cpp:1063: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x0000000015ca95f9 15. /build/src/Storages/StorageFile.cpp:1067: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x0000000015ca9c5c 16. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], String const&, String, bool, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x00000000117228aa 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x0000000011720b78 18. /build/src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000011723a7c 19. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000130d4903 20. /build/src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000143537f2 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000013f3da49 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642a1 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 25. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 26. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 31. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 2025.07.13 02:19:50.469489 [ 37313 ] {a6ef91f7-2393-482a-980c-0a31e1a87292} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingAvg should be positive integer. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35740) (comment: 02817_group_array_moving_zero_window_size.sql) (query 1, line 1) (in query: SELECT groupArrayMovingAvg ( toInt64 ( 0 ) ) ( toDecimal32 ( 1 , 1 ) );), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:272: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000001141d9bb 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130caa1d 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:19:50.507670 [ 37313 ] {} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingAvg should be positive integer. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:272: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000001141d9bb 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000130caa1d 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000130c9a0a 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f5204d 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 21. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 22. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 27. ? @ 0x00007f7210eb6ac3 28. ? @ 0x00007f7210f48850 2025.07.13 02:19:52.500034 [ 30862 ] {72f825f8-b387-41ea-9ee3-4d077f542579} executeQuery: Code: 42. DB::Exception: Number of arguments for function locate doesn't match: passed 0, should be 2 or 3: In scope SELECT locate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35776) (comment: 00765_locate.sql) (query 3, line 4) (in query: SELECT locate();), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000009fb386b 4. /build/src/Functions/FunctionsStringSearch.h:137: DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)1>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000ce7f762 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:19:52.512352 [ 30862 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function locate doesn't match: passed 0, should be 2 or 3: In scope SELECT locate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000009fb386b 4. /build/src/Functions/FunctionsStringSearch.h:137: DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)1>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000ce7f762 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:19:52.766517 [ 30862 ] {049cff61-fdff-4565-8f1e-e203d5660a6d} executeQuery: Code: 43. DB::Exception: Illegal type String of argument of function locate: In scope SELECT locate(1, 'abc'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35776) (comment: 00765_locate.sql) (query 4, line 5) (in query: SELECT locate(1, 'abc');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/FunctionsStringSearch.h:152: DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)1>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000ce7f811 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:19:52.772514 [ 30862 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of argument of function locate: In scope SELECT locate(1, 'abc'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/FunctionsStringSearch.h:152: DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)1>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000ce7f811 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:19:52.935409 [ 30862 ] {8fa71995-3d9a-43e7-b893-95a310039a1a} executeQuery: Code: 43. DB::Exception: Illegal type String of argument of function locate: In scope SELECT locate('abc', 1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35776) (comment: 00765_locate.sql) (query 5, line 6) (in query: SELECT locate('abc', 1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/FunctionsStringSearch.h:146: DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)1>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000ce7f8c6 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:19:52.960673 [ 30862 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of argument of function locate: In scope SELECT locate('abc', 1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/FunctionsStringSearch.h:146: DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)1>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000ce7f8c6 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:19:53.293097 [ 30862 ] {ad7bc9c8-32f6-4901-a0f8-1b2754e85708} executeQuery: Code: 43. DB::Exception: Illegal type String of argument of function locate: In scope SELECT locate('abc', 'abc', 'abc'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35776) (comment: 00765_locate.sql) (query 6, line 7) (in query: SELECT locate('abc', 'abc', 'abc');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/FunctionsStringSearch.h:160: DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)1>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000ce7f96e 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:19:53.301099 [ 30862 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of argument of function locate: In scope SELECT locate('abc', 'abc', 'abc'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/FunctionsStringSearch.h:160: DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)1>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000ce7f96e 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009fae2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:19:54.239233 [ 47970 ] {} ExternalDictionariesLoader: Could not load external dictionary '0ca1414e-e1b1-4e07-bc23-aa654781fa7d', next update is scheduled at 2025-07-13 02:20:00: Code: 36. DB::Exception: 0ca1414e-e1b1-4e07-bc23-aa654781fa7d: SHARDS parameter does not supports for updatable source (UPDATE_FIELD). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Dictionaries/registerHashedDictionary.cpp:89: DB::registerDictionaryHashed(DB::DictionaryFactory&)::$_4::operator()(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, DB::DictionaryKeyType, bool) const @ 0x0000000011c50410 5. /build/src/Dictionaries/registerHashedDictionary.cpp:127: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:se190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x0000000011c509d9 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012c74f5d 7. /build/src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000147cade4 8. /build/src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000147d6c48 9. /build/src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000147d56dd 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000147d96f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:19:54.266036 [ 4626 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:19:55.672422 [ 5998 ] {472f6344-5c72-427e-8c73-6e068f2a6684} executeQuery: Code: 80. DB::Exception: Failed to rewrite ' test_4esnyn6h.t1 AS __table1 ALL INNER JOIN test_4esnyn6h.t2 AS __table2 ON __table1.a = if(__table2.b > 0, __table2.a, 0), (SELECT __table4.a AS x FROM test_4esnyn6h.t3 AS __table4 WHERE (__table4.a + 1) = __table4.b) AS __table3' to INNER JOIN: no equi-join conditions found in WHERE clause. You may set setting `cross_to_inner_join_rewrite` to `1` to allow slow CROSS JOIN for this case. (INCORRECT_QUERY) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:56288) (comment: 02564_analyzer_cross_to_inner.sql) (query 31, line 84) (in query: -- { echoOff } SELECT * FROM t1, t2, (SELECT a as x from t3 where a + 1 = b ) as t3 WHERE t1.a = if(t2.b > 0, t2.a, 0) SETTINGS cross_to_inner_join_rewrite = 2;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Analyzer/Passes/CrossToInnerJoinPass.cpp:355: DB::(anonymous namespace)::CrossToInnerJoinVisitor::checkNotRewritten(bool, std::shared_ptr const&) @ 0x00000000141d3500 5. /build/src/Analyzer/Passes/CrossToInnerJoinPass.cpp:282: DB::InDepthQueryTreeVisitorWithContext::visit(std::shared_ptr&) @ 0x00000000141d1e4a 6. /build/src/Analyzer/Passes/CrossToInnerJoinPass.cpp:392: DB::CrossToInnerJoinPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000141d0312 7. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 12. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 14. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 15. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 20. ? @ 0x00007f7210eb6ac3 21. ? @ 0x00007f7210f48850 2025.07.13 02:19:55.680109 [ 5998 ] {} TCPHandler: Code: 80. DB::Exception: Failed to rewrite ' test_4esnyn6h.t1 AS __table1 ALL INNER JOIN test_4esnyn6h.t2 AS __table2 ON __table1.a = if(__table2.b > 0, __table2.a, 0), (SELECT __table4.a AS x FROM test_4esnyn6h.t3 AS __table4 WHERE (__table4.a + 1) = __table4.b) AS __table3' to INNER JOIN: no equi-join conditions found in WHERE clause. You may set setting `cross_to_inner_join_rewrite` to `1` to allow slow CROSS JOIN for this case. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000009faf56b 4. /build/src/Analyzer/Passes/CrossToInnerJoinPass.cpp:355: DB::(anonymous namespace)::CrossToInnerJoinVisitor::checkNotRewritten(bool, std::shared_ptr const&) @ 0x00000000141d3500 5. /build/src/Analyzer/Passes/CrossToInnerJoinPass.cpp:282: DB::InDepthQueryTreeVisitorWithContext::visit(std::shared_ptr&) @ 0x00000000141d1e4a 6. /build/src/Analyzer/Passes/CrossToInnerJoinPass.cpp:392: DB::CrossToInnerJoinPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000141d0312 7. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 12. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 14. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 15. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 20. ? @ 0x00007f7210eb6ac3 21. ? @ 0x00007f7210f48850 2025.07.13 02:19:58.567124 [ 3557 ] {} DNSResolver: Cannot resolve host (localhos), error 0: Host not found. 2025.07.13 02:19:59.452306 [ 11479 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:20:00.078145 [ 16763 ] {182d04eb-1374-4b21-b474-84274f0976e9} 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]:42126) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000013f69e39 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f3a889 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5014: DB::QueryAnalyzer::resolveArrayJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f63da3 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5333: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642c7 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:20:00.095973 [ 16763 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000013f69e39 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f3a889 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5014: DB::QueryAnalyzer::resolveArrayJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f63da3 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5333: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000013f642c7 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f32104 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:20:04.178413 [ 39962 ] {} ExternalDictionariesLoader: Could not load external dictionary '02ea2b3a-7cb3-4b74-abb1-4f80305a92a9', next update is scheduled at 2025-07-13 02:20:28: Code: 482. DB::Exception: Dictionaries with executable dictionary source are not allowed to be created from DDL query. (DICTIONARY_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Dictionaries/ExecutableDictionarySource.cpp:233: std::shared_ptr std::__function::__policy_invoker (DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr, String const&, bool)>::__call_impl[abi:se190107] (DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr, String const&, bool)>>(std::__function::__policy_storage const*, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr&&, String const&, bool) @ 0x00000000119c8c6b 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012c76e33 6. /build/src/Dictionaries/DictionaryFactory.cpp:47: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x0000000012c74a2d 7. /build/src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000147cade4 8. /build/src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000147d6c48 9. /build/src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000147d56dd 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000147d96f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:20:04.235681 [ 30860 ] {5958237f-d796-419e-bf89-06d095dfb564} 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: 02845_join_on_cond_sparse.sql) (in query: /* ddl_entry=query-0000000162 */ CREATE TABLE test_5.t1 UUID '697a4452-4daa-4e07-bd23-c79cb85cb6b2' (`id` UInt32, `attr` UInt32) ENGINE = MergeTree ORDER BY id SETTINGS ratio_of_defaults_for_sparse_serialization = 0.1, index_granularity = 13510, min_bytes_for_wide_part = 0, replace_long_file_name_to_hash = false, max_file_name_length = 71, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 217085353, compact_parts_max_granules_to_buffer = 139, compact_parts_merge_max_bytes_to_prefetch_part = 17607589, merge_max_block_size = 20289, old_parts_lifetime = 261., prefer_fetch_merged_part_size_threshold = 5384272703, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 9017008032, index_granularity_bytes = 17670432, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 38, 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 = 86610, primary_key_compress_block_size = 94704, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 12. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:20:04.321763 [ 30862 ] {98d9531c-b253-4957-a2c4-d0b92bfea6c2} 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]:42248) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000012c9192b 4. /build/src/Functions/FunctionHelpers.cpp:184: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c90171 5. /build/src/Functions/compareSubstrings.cpp:49: DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b14917e 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:20:04.325618 [ 39963 ] {} ExternalDictionariesLoader: Could not load external dictionary '0ca1414e-e1b1-4e07-bc23-aa654781fa7d', next update is scheduled at 2025-07-13 02:20:17: Code: 36. DB::Exception: 0ca1414e-e1b1-4e07-bc23-aa654781fa7d: SHARDS parameter does not supports for updatable source (UPDATE_FIELD). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Dictionaries/registerHashedDictionary.cpp:89: DB::registerDictionaryHashed(DB::DictionaryFactory&)::$_4::operator()(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, DB::DictionaryKeyType, bool) const @ 0x0000000011c50410 5. /build/src/Dictionaries/registerHashedDictionary.cpp:127: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:se190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x0000000011c509d9 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012c74f5d 7. /build/src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000147cade4 8. /build/src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000147d6c48 9. /build/src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000147d56dd 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000147d96f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:20:04.331301 [ 30862 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000012c9192b 4. /build/src/Functions/FunctionHelpers.cpp:184: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c90171 5. /build/src/Functions/compareSubstrings.cpp:49: DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b14917e 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:20:04.361956 [ 47955 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:20:04.390722 [ 30862 ] {3d3d85d9-471f-4aa6-82dd-9ef6f585579d} 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]:42248) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000012c9192b 4. /build/src/Functions/FunctionHelpers.cpp:184: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c90171 5. /build/src/Functions/compareSubstrings.cpp:49: DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b14917e 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:20:04.399805 [ 30862 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000012c9192b 4. /build/src/Functions/FunctionHelpers.cpp:184: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c90171 5. /build/src/Functions/compareSubstrings.cpp:49: DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b14917e 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:20:04.468581 [ 30860 ] {5958237f-d796-419e-bf89-06d095dfb564} executeQuery: Code: 57. DB::Exception: Table test_5.t1 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42210) (comment: 02845_join_on_cond_sparse.sql) (query 3, line 4) (in query: CREATE TABLE t1 (`id` UInt32, `attr` UInt32) ENGINE = MergeTree ORDER BY id SETTINGS ratio_of_defaults_for_sparse_serialization = 0.1, index_granularity = 13510, min_bytes_for_wide_part = 0, replace_long_file_name_to_hash = false, max_file_name_length = 71, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 217085353, compact_parts_max_granules_to_buffer = 139, compact_parts_merge_max_bytes_to_prefetch_part = 17607589, merge_max_block_size = 20289, old_parts_lifetime = 261., prefer_fetch_merged_part_size_threshold = 5384272703, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 9017008032, index_granularity_bytes = 17670432, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 38, 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 = 86610, primary_key_compress_block_size = 94704, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 12. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:20:04.485011 [ 30860 ] {} TCPHandler: Code: 57. DB::Exception: Table test_5.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013ce704b 12. /build/src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013cc3e7c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014817c78 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 17. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 18. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 23. ? @ 0x00007f7210eb6ac3 24. ? @ 0x00007f7210f48850 2025.07.13 02:20:04.646392 [ 30862 ] {95c27517-a3df-4e7f-becd-ae433888f241} 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]:42248) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000012c9192b 4. /build/src/Functions/FunctionHelpers.cpp:184: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c90171 5. /build/src/Functions/compareSubstrings.cpp:49: DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b14917e 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:20:04.694306 [ 30862 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000012c9192b 4. /build/src/Functions/FunctionHelpers.cpp:184: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c90171 5. /build/src/Functions/compareSubstrings.cpp:49: DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b14917e 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:20:04.872943 [ 30862 ] {a2aac07f-0708-48f7-92b9-fe508e65117d} 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]:42248) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000012c9192b 4. /build/src/Functions/FunctionHelpers.cpp:184: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c90171 5. /build/src/Functions/compareSubstrings.cpp:49: DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b14917e 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:20:04.894212 [ 30862 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000012c9192b 4. /build/src/Functions/FunctionHelpers.cpp:184: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c90171 5. /build/src/Functions/compareSubstrings.cpp:49: DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b14917e 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:20:05.041718 [ 30862 ] {3ca02f9c-0fb5-4b9f-b01a-176ac4e8f305} 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]:42248) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000012c9192b 4. /build/src/Functions/FunctionHelpers.cpp:184: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c90171 5. /build/src/Functions/compareSubstrings.cpp:49: DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b14917e 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:20:05.060372 [ 30862 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000012c9192b 4. /build/src/Functions/FunctionHelpers.cpp:184: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c90171 5. /build/src/Functions/compareSubstrings.cpp:49: DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b14917e 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:20:05.260857 [ 30862 ] {e13e4cb7-b84f-4144-b130-09e69e63c030} 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]:42248) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000012c9192b 4. /build/src/Functions/FunctionHelpers.cpp:184: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c90171 5. /build/src/Functions/compareSubstrings.cpp:49: DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b14917e 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:20:05.316049 [ 30862 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000012c9192b 4. /build/src/Functions/FunctionHelpers.cpp:184: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c90171 5. /build/src/Functions/compareSubstrings.cpp:49: DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b14917e 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:20:05.579397 [ 30862 ] {662c6571-8e44-4926-8a49-ea2f4dcc94fc} 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]:42248) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/compareSubstrings.cpp:49: DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b14917e 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:20:05.588749 [ 30862 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/compareSubstrings.cpp:49: DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b14917e 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:20:05.755854 [ 30862 ] {f47cd6da-0c07-4012-8e61-51a2d5226f72} 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]:42248) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/compareSubstrings.cpp:49: DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b14917e 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:20:05.770765 [ 30862 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/compareSubstrings.cpp:49: DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b14917e 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:20:05.882684 [ 30862 ] {477702a0-f8aa-4053-980d-b5bbcd8ae9d7} 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]:42248) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/compareSubstrings.cpp:49: DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b14917e 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:20:05.896257 [ 30862 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/compareSubstrings.cpp:49: DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b14917e 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:20:06.138237 [ 30862 ] {88622344-87bc-4405-a80e-f3afbc1b6b40} 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]:42248) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/compareSubstrings.cpp:49: DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b14917e 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:20:06.146591 [ 30862 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/compareSubstrings.cpp:49: DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b14917e 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:20:06.258685 [ 30862 ] {66956808-20c7-47a8-809a-0b46d5587284} 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]:42248) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/compareSubstrings.cpp:49: DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b14917e 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:20:06.296544 [ 30862 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/compareSubstrings.cpp:49: DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b14917e 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:20:06.500104 [ 30862 ] {6ae7c3b8-7a82-4fb5-b97e-dcc88bcf76f9} 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]:42248) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/compareSubstrings.cpp:49: DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b14917e 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:20:06.560665 [ 30862 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/compareSubstrings.cpp:49: DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b14917e 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:20:06.717420 [ 30862 ] {2afbf239-ee93-4408-83c4-3eb248108100} 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]:42248) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/compareSubstrings.cpp:49: DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b14917e 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:20:06.767688 [ 30862 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/compareSubstrings.cpp:49: DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b14917e 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:20:06.883813 [ 30862 ] {5945392d-0d2e-4613-9ea0-5b7f2900c8a5} 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]:42248) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/compareSubstrings.cpp:49: DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b14917e 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:20:06.897276 [ 30862 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000012c91e19 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012c90455 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012c8fe3b 6. /build/src/Functions/compareSubstrings.cpp:49: DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b14917e 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012c8144c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012c80fdc 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012c8181c 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52d29 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:20:07.856254 [ 4547 ] {e8b3f4dd-db2b-469f-93cc-98a5aa696220} RestorerFromBackup: Tables test_13.mv in backup depend on test_13.src, but seems like test_13.src is not in the backup and does not exist. Will try to ignore that and restore tables 2025.07.13 02:20:07.968885 [ 4888 ] {} TCPHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000013779f8b 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000137794b8 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778c58 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168167bf 10. /build/src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000001680ff45 11. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:20:07.972789 [ 4888 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x0000000016810069 5. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 6. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 2025.07.13 02:20:08.070536 [ 4922 ] {43eedf26-d74b-4338-96d4-cf933baf2626} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000013779f8b 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000137794b8 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778c58 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168167bf 10. /build/src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000001680ff45 11. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:35830) (comment: 00294_shard_enums.sql) (query 40, line 79) (in query: create table enums_copy engine = TinyLog as select * from remote('127.0.0.2', currentDatabase(), enums);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fb80677 3. /build/src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x00000000166f5247 4. /build/src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000166fc432 5. /build/src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001673a5f3 6. /build/src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013af6952 7. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013af679a 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013af64e1 2025.07.13 02:20:08.125630 [ 4922 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000013779f8b 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000137794b8 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778c58 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168167bf 10. /build/src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000001680ff45 11. /build/src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x0000000016806494 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fb80677 3. /build/src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x00000000166f5247 4. /build/src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x00000000166fc432 5. /build/src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001673a5f3 6. /build/src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013af6952 7. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013af679a 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013af64e1 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x00000000168cf907 5. /build/src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000001680710e 6. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 2025.07.13 02:20:09.492085 [ 11497 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:20:10.438481 [ 31799 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000013779f8b 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000137794b8 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001377894f 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013778bc3 7. /build/src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014355374 8. /build/src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001435586b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678d325 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:20:12.610361 [ 16758 ] {971b9d71-c5e2-4dd6-b018-7dbad31d829d} executeQuery: Code: 701. DB::Exception: Reading in parallel from replicas is enabled but cluster to execute query is not provided. Please set 'cluster_for_parallel_replicas' setting. (CLUSTER_DOESNT_EXIST) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40956) (comment: 02935_parallel_replicas_settings.sql) (query 7, line 9) (in query: SELECT count() FROM test_parallel_replicas_settings WHERE NOT ignore(*);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/Context.cpp:6311: DB::Context::getClusterForParallelReplicas() const @ 0x0000000014370831 5. /build/src/Interpreters/ClusterProxy/executeQuery.cpp:824: DB::ClusterProxy::canUseParallelReplicasOnInitiator(std::shared_ptr const&) @ 0x00000000157d0626 6. /build/src/Planner/PlannerJoinTree.cpp:1012: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000148b60a2 7. /build/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&) @ 0x00000000148ad029 8. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 9. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:20:12.642758 [ 16758 ] {} TCPHandler: Code: 701. DB::Exception: Reading in parallel from replicas is enabled but cluster to execute query is not provided. Please set 'cluster_for_parallel_replicas' setting. (CLUSTER_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/Context.cpp:6311: DB::Context::getClusterForParallelReplicas() const @ 0x0000000014370831 5. /build/src/Interpreters/ClusterProxy/executeQuery.cpp:824: DB::ClusterProxy::canUseParallelReplicasOnInitiator(std::shared_ptr const&) @ 0x00000000157d0626 6. /build/src/Planner/PlannerJoinTree.cpp:1012: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000148b60a2 7. /build/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&) @ 0x00000000148ad029 8. /build/src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000001489876e 9. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:20:14.471375 [ 39963 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:20:19.797419 [ 47970 ] {} ExternalDictionariesLoader: Could not load external dictionary '0ca1414e-e1b1-4e07-bc23-aa654781fa7d', next update is scheduled at 2025-07-13 02:20:27: Code: 36. DB::Exception: 0ca1414e-e1b1-4e07-bc23-aa654781fa7d: SHARDS parameter does not supports for updatable source (UPDATE_FIELD). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Dictionaries/registerHashedDictionary.cpp:89: DB::registerDictionaryHashed(DB::DictionaryFactory&)::$_4::operator()(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, DB::DictionaryKeyType, bool) const @ 0x0000000011c50410 5. /build/src/Dictionaries/registerHashedDictionary.cpp:127: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:se190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x0000000011c509d9 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012c74f5d 7. /build/src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000147cade4 8. /build/src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000147d6c48 9. /build/src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000147d56dd 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000147d96f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:20:19.812733 [ 47953 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:20:21.226667 [ 16757 ] {9c9d5021-0c52-4573-88c8-0c90c52d0f9e} 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]:45704) (comment: 01460_line_as_string_format.sh) (in query: DROP DATABASE IF EXISTS test_5ne8u3h5 SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:20:21.265457 [ 16757 ] {9c9d5021-0c52-4573-88c8-0c90c52d0f9e} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:20:21.670384 [ 3645 ] {} DNSResolver: Cannot resolve host (localhos), error 0: Host not found. 2025.07.13 02:20:26.119616 [ 12992 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:20:27.093449 [ 12992 ] {} ExternalDictionariesLoader: Could not update external dictionary 'd6fbfd16-05c4-4288-b325-142078f64329', leaving the previous version, next update is scheduled at 2025-07-13 02:20:33: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda7a6 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 9. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:20:30.169063 [ 10910 ] {} ExternalDictionariesLoader: Could not load external dictionary '02ea2b3a-7cb3-4b74-abb1-4f80305a92a9', next update is scheduled at 2025-07-13 02:23:31: Code: 482. DB::Exception: Dictionaries with executable dictionary source are not allowed to be created from DDL query. (DICTIONARY_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Dictionaries/ExecutableDictionarySource.cpp:233: std::shared_ptr std::__function::__policy_invoker (DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr, String const&, bool)>::__call_impl[abi:se190107] (DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr, String const&, bool)>>(std::__function::__policy_storage const*, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr&&, String const&, bool) @ 0x00000000119c8c6b 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012c76e33 6. /build/src/Dictionaries/DictionaryFactory.cpp:47: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x0000000012c74a2d 7. /build/src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000147cade4 8. /build/src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000147d6c48 9. /build/src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000147d56dd 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000147d96f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:20:30.433125 [ 6027 ] {} ExternalDictionariesLoader: Could not load external dictionary '0ca1414e-e1b1-4e07-bc23-aa654781fa7d', next update is scheduled at 2025-07-13 02:20:44: Code: 36. DB::Exception: 0ca1414e-e1b1-4e07-bc23-aa654781fa7d: SHARDS parameter does not supports for updatable source (UPDATE_FIELD). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Dictionaries/registerHashedDictionary.cpp:89: DB::registerDictionaryHashed(DB::DictionaryFactory&)::$_4::operator()(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, DB::DictionaryKeyType, bool) const @ 0x0000000011c50410 5. /build/src/Dictionaries/registerHashedDictionary.cpp:127: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:se190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x0000000011c509d9 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012c74f5d 7. /build/src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000147cade4 8. /build/src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000147d6c48 9. /build/src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000147d56dd 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000147d96f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:20:30.691055 [ 16758 ] {4d351268-d7c7-42d2-99a7-6566c3c999a1} executeQueryWithParallelReplicas: Setting 'use_hedged_requests' explicitly with enabled 'enable_parallel_replicas' has no effect. Hedged connections are not used for parallel reading from replicas 2025.07.13 02:20:32.428649 [ 50289 ] {a0db3f21-09f0-4510-ad40-907bdcf069e2} executeQuery: Code: 70. DB::Exception: Conversion from IntervalDay to Decimal(10, 10) is not supported: In scope SELECT CAST(toIntervalDay(1), 'Nullable(Decimal(10, 10))'). (CANNOT_CONVERT_TYPE) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40582) (comment: 00879_cast_to_decimal_crash.sql) (query 1, line 1) (in query: select cast(toIntervalDay(1) as Nullable(Decimal(10, 10)));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/FunctionsConversion.h:3740: 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 @ 0x0000000012dd26f8 5. /build/src/Functions/FunctionsConversion.h:5953: DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000012cd8227 6. /build/src/Functions/FunctionsConversion.h:5819: DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000012cc817b 7. /build/src/Functions/FunctionsConversion.h:5746: DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000012cc6f09 8. /build/src/Functions/FunctionsConversion.h:3444: DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x0000000012cc67f0 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3557: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52bc0 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:20:32.433570 [ 50289 ] {} TCPHandler: Code: 70. DB::Exception: Conversion from IntervalDay to Decimal(10, 10) is not supported: In scope SELECT CAST(toIntervalDay(1), 'Nullable(Decimal(10, 10))'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/FunctionsConversion.h:3740: 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 @ 0x0000000012dd26f8 5. /build/src/Functions/FunctionsConversion.h:5953: DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000012cd8227 6. /build/src/Functions/FunctionsConversion.h:5819: DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000012cc817b 7. /build/src/Functions/FunctionsConversion.h:5746: DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000012cc6f09 8. /build/src/Functions/FunctionsConversion.h:3444: DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x0000000012cc67f0 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3557: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f52bc0 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 23. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 24. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 29. ? @ 0x00007f7210eb6ac3 30. ? @ 0x00007f7210f48850 2025.07.13 02:20:35.679688 [ 4858 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:20:38.869828 [ 5998 ] {a0da621d-0646-47da-95c5-0aa9151b6182} executeQuery: Code: 36. DB::Exception: Illegal (null) value column Nullable(UInt64) of argument of function range: In scope SELECT range(CAST(NULL, 'Nullable(UInt64)'), CAST('10', 'Nullable(UInt64)'), CAST('2', 'Nullable(UInt64)')). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40584) (comment: 02797_range_nullable.sql) (query 9, line 9) (in query: SELECT range(Null::Nullable(UInt64), 10::Nullable(UInt64), 2::Nullable(UInt64));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/array/range.cpp:419: DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnWithTypeAndName const&)::operator()(DB::ColumnWithTypeAndName const&) const @ 0x000000000fa5a84e 5. /build/src/Functions/array/range.cpp:447: DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fa57d90 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:20:38.962177 [ 5998 ] {} TCPHandler: Code: 36. DB::Exception: Illegal (null) value column Nullable(UInt64) of argument of function range: In scope SELECT range(CAST(NULL, 'Nullable(UInt64)'), CAST('10', 'Nullable(UInt64)'), CAST('2', 'Nullable(UInt64)')). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/array/range.cpp:419: DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnWithTypeAndName const&)::operator()(DB::ColumnWithTypeAndName const&) const @ 0x000000000fa5a84e 5. /build/src/Functions/array/range.cpp:447: DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fa57d90 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:20:39.441968 [ 5998 ] {ae9679f6-4925-4483-bd17-7f85b422714b} executeQuery: Code: 36. DB::Exception: Illegal (null) value column Nullable(UInt64) of argument of function range: In scope SELECT range(CAST('0', 'Nullable(UInt64)'), CAST(NULL, 'Nullable(UInt64)'), CAST('2', 'Nullable(UInt64)')). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40584) (comment: 02797_range_nullable.sql) (query 10, line 10) (in query: SELECT range(0::Nullable(UInt64), Null::Nullable(UInt64), 2::Nullable(UInt64));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/array/range.cpp:419: DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnWithTypeAndName const&)::operator()(DB::ColumnWithTypeAndName const&) const @ 0x000000000fa5a84e 5. /build/src/Functions/array/range.cpp:447: DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fa57d90 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:20:39.527249 [ 5998 ] {} TCPHandler: Code: 36. DB::Exception: Illegal (null) value column Nullable(UInt64) of argument of function range: In scope SELECT range(CAST('0', 'Nullable(UInt64)'), CAST(NULL, 'Nullable(UInt64)'), CAST('2', 'Nullable(UInt64)')). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/array/range.cpp:419: DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnWithTypeAndName const&)::operator()(DB::ColumnWithTypeAndName const&) const @ 0x000000000fa5a84e 5. /build/src/Functions/array/range.cpp:447: DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fa57d90 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:20:39.968249 [ 5998 ] {2e09f82c-f229-49e7-b8ee-a6450eadee4c} executeQuery: Code: 36. DB::Exception: Illegal (null) value column Nullable(UInt64) of argument of function range: In scope SELECT range(CAST('0', 'Nullable(UInt64)'), CAST('10', 'Nullable(UInt64)'), CAST(NULL, 'Nullable(UInt64)')). (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40584) (comment: 02797_range_nullable.sql) (query 11, line 11) (in query: SELECT range(0::Nullable(UInt64), 10::Nullable(UInt64), Null::Nullable(UInt64));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/array/range.cpp:419: DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnWithTypeAndName const&)::operator()(DB::ColumnWithTypeAndName const&) const @ 0x000000000fa5a84e 5. /build/src/Functions/array/range.cpp:447: DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fa57d90 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:20:40.071285 [ 5998 ] {} TCPHandler: Code: 36. DB::Exception: Illegal (null) value column Nullable(UInt64) of argument of function range: In scope SELECT range(CAST('0', 'Nullable(UInt64)'), CAST('10', 'Nullable(UInt64)'), CAST(NULL, 'Nullable(UInt64)')). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/array/range.cpp:419: DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnWithTypeAndName const&)::operator()(DB::ColumnWithTypeAndName const&) const @ 0x000000000fa5a84e 5. /build/src/Functions/array/range.cpp:447: DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fa57d90 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 27. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 28. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 2025.07.13 02:20:40.508380 [ 5998 ] {3765421f-809e-4690-8d02-b39af838d745} executeQuery: Code: 36. DB::Exception: Illegal (null) value column Const(Nullable(UInt8)) of argument of function range. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40584) (comment: 02797_range_nullable.sql) (query 12, line 12) (in query: SELECT range(Null::Nullable(UInt8), materialize(1));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/array/range.cpp:419: DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnWithTypeAndName const&)::operator()(DB::ColumnWithTypeAndName const&) const @ 0x000000000fa5a84e 5. /build/src/Functions/array/range.cpp:447: DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fa57d90 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 11. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013ec18ac 12. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013ec09aa 13. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016b30052 14. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016cdda71 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000130d8a1a 16. /build/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>>&) @ 0x00000000148a05bd 17. /build/src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000001489a16a 18. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 20. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:20:40.538367 [ 5998 ] {} TCPHandler: Code: 36. DB::Exception: Illegal (null) value column Const(Nullable(UInt8)) of argument of function range. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Functions/array/range.cpp:419: DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnWithTypeAndName const&)::operator()(DB::ColumnWithTypeAndName const&) const @ 0x000000000fa5a84e 5. /build/src/Functions/array/range.cpp:447: DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fa57d90 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 11. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013ec18ac 12. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013ec09aa 13. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016b30052 14. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016cdda71 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000130d8a1a 16. /build/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>>&) @ 0x00000000148a05bd 17. /build/src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000001489a16a 18. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 20. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 22. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 23. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 28. ? @ 0x00007f7210eb6ac3 29. ? @ 0x00007f7210f48850 2025.07.13 02:20:40.911010 [ 12972 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:20:45.957632 [ 47966 ] {} ExternalDictionariesLoader: Could not load external dictionary '0ca1414e-e1b1-4e07-bc23-aa654781fa7d', next update is scheduled at 2025-07-13 02:20:53: Code: 36. DB::Exception: 0ca1414e-e1b1-4e07-bc23-aa654781fa7d: SHARDS parameter does not supports for updatable source (UPDATE_FIELD). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Dictionaries/registerHashedDictionary.cpp:89: DB::registerDictionaryHashed(DB::DictionaryFactory&)::$_4::operator()(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, DB::DictionaryKeyType, bool) const @ 0x0000000011c50410 5. /build/src/Dictionaries/registerHashedDictionary.cpp:127: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:se190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x0000000011c509d9 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012c74f5d 7. /build/src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000147cade4 8. /build/src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000147d6c48 9. /build/src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000147d56dd 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000147d96f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:20:45.964749 [ 4547 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:20:51.045730 [ 11496 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:20:53.533067 [ 30860 ] {5e840c2a-4571-4d50-85d9-71dee1f21484} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 5.82 MiB (attempt to allocate chunk of 2.00 MiB), maximum: 9.31 GiB: (while reading column d.UInt64): (while reading from part /var/lib/clickhouse/store/9fa/9faf3f37-f780-4e9d-8a40-53e0c789eb9d/all_1_12_2/ in table test_1.test (9faf3f37-f780-4e9d-8a40-53e0c789eb9d) located on disk default of type local, from mark 10 with max_rows_to_read = 73670): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40932) (comment: 03036_dynamic_read_subcolumns_compact_merge_tree.sql) (query 14, line 20) (in query: select count() from test where d.UInt64 is not NULL;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x000000000fb2dd39 4. /build/src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2cb67 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2c5bf 6. /build/src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000fa9410c 7. /build/src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000000fa92864 8. /build/src/Common/PODArray.h:118: DB::SerializationVariant::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000013c56fc3 9. /build/src/DataTypes/Serializations/SerializationArray.cpp:389: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000013ba9c7b 10. /build/src/DataTypes/Serializations/SerializationVariant.cpp:499: DB::SerializationVariant::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000013c56770 11. /build/src/DataTypes/Serializations/SerializationDynamic.cpp:455: DB::SerializationDynamic::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000013bc1720 12. /build/src/Storages/MergeTree/MergeTreeReaderCompact.cpp:200: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x00000000163b425a 13. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000163c87a0 14. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000163bc9b1 15. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000163c3d29 16. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x00000000163de7ba 17. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x00000000163dace0 18. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x0000000016d7ba8c 19. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5584 20. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 21. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 22. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 23. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 24. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 25. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 26. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 27. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:20:53.764598 [ 30860 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 5.82 MiB (attempt to allocate chunk of 2.00 MiB), maximum: 9.31 GiB: (while reading column d.UInt64): (while reading from part /var/lib/clickhouse/store/9fa/9faf3f37-f780-4e9d-8a40-53e0c789eb9d/all_1_12_2/ in table test_1.test (9faf3f37-f780-4e9d-8a40-53e0c789eb9d) located on disk default of type local, from mark 10 with max_rows_to_read = 73670): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x000000000fb2dd39 4. /build/src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2cb67 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2c5bf 6. /build/src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000fa9410c 7. /build/src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000000fa92864 8. /build/src/Common/PODArray.h:118: DB::SerializationVariant::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000013c56fc3 9. /build/src/DataTypes/Serializations/SerializationArray.cpp:389: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000013ba9c7b 10. /build/src/DataTypes/Serializations/SerializationVariant.cpp:499: DB::SerializationVariant::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000013c56770 11. /build/src/DataTypes/Serializations/SerializationDynamic.cpp:455: DB::SerializationDynamic::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000013bc1720 12. /build/src/Storages/MergeTree/MergeTreeReaderCompact.cpp:200: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x00000000163b425a 13. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000163c87a0 14. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000163bc9b1 15. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000163c3d29 16. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x00000000163de7ba 17. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x00000000163dace0 18. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x0000000016d7ba8c 19. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5584 20. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 21. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 22. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 23. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 24. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 25. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1287 26. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 27. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:20:56.110495 [ 40065 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:20:56.219053 [ 47983 ] {} ExternalDictionariesLoader: Could not load external dictionary '0ca1414e-e1b1-4e07-bc23-aa654781fa7d', next update is scheduled at 2025-07-13 02:22:54: Code: 36. DB::Exception: 0ca1414e-e1b1-4e07-bc23-aa654781fa7d: SHARDS parameter does not supports for updatable source (UPDATE_FIELD). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Dictionaries/registerHashedDictionary.cpp:89: DB::registerDictionaryHashed(DB::DictionaryFactory&)::$_4::operator()(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, DB::DictionaryKeyType, bool) const @ 0x0000000011c50410 5. /build/src/Dictionaries/registerHashedDictionary.cpp:127: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:se190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x0000000011c509d9 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012c74f5d 7. /build/src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000147cade4 8. /build/src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000147d6c48 9. /build/src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000147d56dd 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000147d96f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:21:01.135247 [ 3552 ] {} CgroupsReader: Cannot find 'kernel' in '/sys/fs/cgroup/memory.stat' (skipped 5611 similar messages) 2025.07.13 02:21:01.333932 [ 47963 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:21:05.363951 [ 50444 ] {ef8d480f-6935-4ee3-bb30-1bce63e41e72} 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]:37288) (comment: 00104_totals_having_mode.sql) (query 5, line 6) (in query: SET totals_mode = 'before_having';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/executeQuery.cpp:1338: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba8300 5. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 6. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 7. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 12. ? @ 0x00007f7210eb6ac3 13. ? @ 0x00007f7210f48850 2025.07.13 02:21:05.395361 [ 50444 ] {} TCPHandler: Code: 731. DB::Exception: use_query_cache and overflow_mode != 'throw' cannot be used together. (QUERY_CACHE_USED_WITH_NON_THROW_OVERFLOW_MODE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/executeQuery.cpp:1338: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba8300 5. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 6. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 7. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 12. ? @ 0x00007f7210eb6ac3 13. ? @ 0x00007f7210f48850 2025.07.13 02:21:06.599399 [ 47966 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:21:06.739883 [ 47956 ] {176b4f3e-5b4a-4d5a-87dc-eba452e72a23} BackupsWorker: Failed to make internal backup Disk('backups', '02907_backup_mv_with_no_source_table_test_132'): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000118cbf6e 8. /build/src/Backups/BackupFileInfo.cpp:233: DB::buildFileInfosForBackupEntries(std::vector>, std::allocator>>> const&, std::shared_ptr const&, DB::ReadSettings const&, ThreadPoolImpl>&, std::shared_ptr) @ 0x00000000137fa53e 9. /build/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) @ 0x00000000137cb38b 10. /build/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&) @ 0x00000000137ca690 11. /build/src/Backups/BackupsWorker.cpp:418: DB::BackupsWorker::BackupStarter::doBackup() @ 0x00000000137d6570 12. /build/src/Backups/BackupsWorker.cpp:488: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&, std::shared_ptr const&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000137d246c 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013398524 14. /build/contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x0000000013398677 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 18. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x0000000013397daa 5. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:se190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x0000000013397bcf 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000137c888d 7. /build/src/Backups/BackupsWorker.cpp:334: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000137c86d7 8. /build/src/Interpreters/InterpreterBackupQuery.cpp:44: DB::InterpreterBackupQuery::execute() @ 0x0000000014c1cb1d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143febfe 12. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000143fd05e 13. /build/src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000143fa5c2 14. /build/src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x00000000143f374c 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000001440ed62 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 17. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:21:06.747819 [ 47956 ] {176b4f3e-5b4a-4d5a-87dc-eba452e72a23} BackupImpl: An error happened, the backup won't be completed 2025.07.13 02:21:09.010969 [ 50004 ] {ca1c93eb-03cf-4344-93c8-4c8105fc320b} executeQuery: Code: 57. DB::Exception: Table test_3.geo already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:47778) (comment: 01300_read_wkt.sql) (query 21, line 24) (in query: CREATE TABLE geo (s String, id Int) engine=Memory();), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:21:09.059800 [ 50004 ] {} TCPHandler: Code: 57. DB::Exception: Table test_3.geo already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:21:11.762336 [ 47970 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:21:13.385174 [ 37313 ] {0aa512da-9337-4962-b92f-e4c1d15e88c6} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00, current rows: 3.00. (TOO_MANY_ROWS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37316) (comment: 01505_trivial_count_with_partition_predicate.sql) (query 10, line 14) (in query: -- non-optimized (toDate(DateTime) is always monotonic, but we cannot relaxing the predicates to do trivial count()) select count() from test1 where p > toDateTime('2020-09-01 10:00:00');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000013af9d2b 4. /build/src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013af96d2 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x0000000016d41675 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d56e9c 7. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016cf6870 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:21:13.417266 [ 37313 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00, current rows: 3.00. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000013af9d2b 4. /build/src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013af96d2 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x0000000016d41675 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d56e9c 7. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016cf6870 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:21:13.546138 [ 27693 ] {095898c2-6ffb-488b-8ec5-05589380ee2b} executeQuery: Code: 159. DB::Exception: Timeout exceeded (180 s) while flushing system log 'DB::SystemLogQueue'. (TIMEOUT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36270) (comment: 03148_query_log_used_dictionaries.sql) (query 4, line 22) (in query: SYSTEM FLUSH LOGS;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Common/SystemLogBase.cpp:168: DB::SystemLogQueue::waitFlush(long, bool) @ 0x000000000fbee407 5. /build/src/Interpreters/SystemLog.cpp:437: DB::SystemLogs::flush(bool, std::vector> const&) @ 0x0000000014a1ea9f 6. /build/src/Interpreters/InterpreterSystemQuery.cpp:796: DB::InterpreterSystemQuery::execute() @ 0x0000000014bd5a4e 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:21:13.551922 [ 27693 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded (180 s) while flushing system log 'DB::SystemLogQueue'. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Common/SystemLogBase.cpp:168: DB::SystemLogQueue::waitFlush(long, bool) @ 0x000000000fbee407 5. /build/src/Interpreters/SystemLog.cpp:437: DB::SystemLogs::flush(bool, std::vector> const&) @ 0x0000000014a1ea9f 6. /build/src/Interpreters/InterpreterSystemQuery.cpp:796: DB::InterpreterSystemQuery::execute() @ 0x0000000014bd5a4e 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:21:15.571216 [ 37313 ] {ea006a1e-cbfb-4012-9543-637cdedcbcef} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00, current rows: 2.00. (TOO_MANY_ROWS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37316) (comment: 01505_trivial_count_with_partition_predicate.sql) (query 13, line 19) (in query: -- non-optimized (some predicate depends on non-partition_expr columns) select count() FROM test1 where toDate(p) = '2020-09-01' and k = 2;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000013af9d2b 4. /build/src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013af96d2 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x0000000016d41675 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d56e9c 7. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016cf6870 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:21:15.628073 [ 37313 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00, current rows: 2.00. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000013af9d2b 4. /build/src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013af96d2 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x0000000016d41675 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d56e9c 7. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016cf6870 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:21:17.003593 [ 10910 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:21:19.014850 [ 47957 ] {6802aa90-3751-4e42-97ec-7b940ed17c8f} BackupsWorker: Failed to make backup Disk('backups', '02907_backup_mv_with_no_source_table_test_132'): Code: 159. DB::Exception: Timeout exceeded: elapsed 66897.586441 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, unsigned long const&) @ 0x00000000144421ab 4. /build/src/Interpreters/ProcessList.cpp:519: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000001496a7fb 5. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x000000001496af0d 6. /build/src/Backups/BackupCoordinationStageSync.cpp:1178: DB::BackupCoordinationStageSync::checkIfOtherHostsFinish(String const&, std::optional>>, bool, bool&, bool) const @ 0x0000000013831912 7. /build/src/Backups/BackupCoordinationStageSync.cpp:1156: DB::BackupCoordinationStageSync::waitOtherHostsFinishImpl(String const&, std::optional>>, bool) const @ 0x0000000013831348 8. /build/src/Backups/BackupCoordinationStageSync.cpp:1125: DB::BackupCoordinationStageSync::waitOtherHostsFinish(bool) const @ 0x0000000013830bf6 9. /build/src/Backups/BackupsWorker.cpp:568: 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&) @ 0x00000000137ca56f 10. /build/src/Backups/BackupsWorker.cpp:418: DB::BackupsWorker::BackupStarter::doBackup() @ 0x00000000137d6570 11. /build/src/Backups/BackupsWorker.cpp:488: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&, std::shared_ptr const&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000137d246c 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013398524 13. /build/contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x0000000013398677 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 17. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x0000000013397daa 5. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:se190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x0000000013397bcf 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000137c888d 7. /build/src/Backups/BackupsWorker.cpp:334: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000137c86d7 8. /build/src/Interpreters/InterpreterBackupQuery.cpp:44: DB::InterpreterBackupQuery::execute() @ 0x0000000014c1cb1d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:21:19.019471 [ 47957 ] {6802aa90-3751-4e42-97ec-7b940ed17c8f} BackupImpl: An error happened, the backup won't be completed 2025.07.13 02:21:19.181702 [ 49920 ] {group-by-mem-usage-test_e2rdujob} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 339.81 MiB (attempt to allocate chunk of 1.03 MiB), maximum: 1.86 GiB: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:46028) (comment: 02933_group_by_memory_usage.sh) (query 1, line 1) (in query: with q as (select length(groupArray(toString(number))) as x from numbers_mt(2e6) group by number order by x limit 1), q1 as (select * from q), q2 as (select * from q), q3 as (select * from q), q4 as (select * from q) select * from q, q1, q2, q3, q4 settings max_bytes_before_external_group_by='1G', max_bytes_ratio_before_external_group_by = 0, max_memory_usage='2G'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x000000000fb2dd39 4. /build/src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2cb67 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2c5bf 6. /build/src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000fa9410c 7. /build/src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000000fa936fb 8. /build/src/Common/HashTable/HashTable.h:538: HashTable, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator>::resize(unsigned long, unsigned long) @ 0x0000000014567d33 9. /build/src/Common/HashTable/HashTable.h:926: void DB::Aggregator::executeImplBatch, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, false, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x0000000014601e4b 10. /build/src/Interpreters/Aggregator.cpp:0: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, false, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x0000000014600040 11. /build/src/Interpreters/Aggregator.cpp:952: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>, true, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>, true, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x000000001452372f 12. /build/src/Interpreters/Aggregator.cpp:922: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x00000000144b3e5c 13. /build/src/Interpreters/Aggregator.cpp:1587: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x00000000144b7f40 14. /build/src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000016b170dc 15. /build/src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000016b14746 16. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 17. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 18. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 19. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 23. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:21:22.218211 [ 47969 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:21:22.935732 [ 50444 ] {f72966c1-9f05-48e7-ac60-6a48b098b452} 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]:58326) (comment: 01329_compare_tuple_string_constant.sql) (query 1, line 1) (in query: SELECT tuple(1) < '';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/IO/ReadHelpers.cpp:95: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000000fb7e1e9 5. /build/src/IO/ReadHelpers.h:204: void DB::SerializationTuple::deserializeTextImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x0000000013c477c5 6. /build/src/Interpreters/convertFieldToType.cpp:578: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014b775e9 7. /build/src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014b75587 8. /build/src/Functions/FunctionsComparison.h:925: DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c999a91 9. /build/src/Functions/FunctionsComparison.h:1361: DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c980ddf 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 29. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 30. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 2025.07.13 02:21:22.981762 [ 50444 ] {} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected '(' at end of stream.: while converting '' to Tuple(UInt8): In scope SELECT tuple(1) < ''. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000009fc4b2b 4. /build/src/IO/ReadHelpers.cpp:95: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000000fb7e1e9 5. /build/src/IO/ReadHelpers.h:204: void DB::SerializationTuple::deserializeTextImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x0000000013c477c5 6. /build/src/Interpreters/convertFieldToType.cpp:578: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014b775e9 7. /build/src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014b75587 8. /build/src/Functions/FunctionsComparison.h:925: DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c999a91 9. /build/src/Functions/FunctionsComparison.h:1361: DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c980ddf 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 29. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 30. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 2025.07.13 02:21:23.343361 [ 50444 ] {e10011da-f0e8-4b9c-8654-fb51e8557f14} 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]:58326) (comment: 01329_compare_tuple_string_constant.sql) (query 2, line 2) (in query: SELECT tuple(1) < materialize('');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000dda78ab 4. /build/src/DataTypes/getLeastSupertype.cpp:69: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x0000000013b8f59e 5. /build/src/DataTypes/getLeastSupertype.cpp:401: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000013b92b3b 6. /build/src/Functions/FunctionsComparison.h:1149: DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000c99aa33 7. /build/src/Functions/FunctionsComparison.h:1429: DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c981974 8. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 9. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013ec18ac 14. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013ec09aa 15. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016b30052 16. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016cdda71 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000130d8a1a 18. /build/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>>&) @ 0x00000000148a05bd 19. /build/src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000001489a16a 20. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 22. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:21:23.440977 [ 50444 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Tuple(UInt8), String because some of them are Tuple and some of them are not. (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000dda78ab 4. /build/src/DataTypes/getLeastSupertype.cpp:69: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x0000000013b8f59e 5. /build/src/DataTypes/getLeastSupertype.cpp:401: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000013b92b3b 6. /build/src/Functions/FunctionsComparison.h:1149: DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000c99aa33 7. /build/src/Functions/FunctionsComparison.h:1429: DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c981974 8. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fadf2a 9. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012c83f9a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f999 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 13. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013ec18ac 14. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013ec09aa 15. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016b30052 16. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016cdda71 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000130d8a1a 18. /build/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>>&) @ 0x00000000148a05bd 19. /build/src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000001489a16a 20. /build/src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000148951fc 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001489310d 22. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6786 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 24. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 25. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 30. ? @ 0x00007f7210eb6ac3 31. ? @ 0x00007f7210f48850 2025.07.13 02:21:24.595394 [ 49920 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 339.81 MiB (attempt to allocate chunk of 1.03 MiB), maximum: 1.86 GiB: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x000000000fb2dd39 4. /build/src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2cb67 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fb2c5bf 6. /build/src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000fa9410c 7. /build/src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000000fa936fb 8. /build/src/Common/HashTable/HashTable.h:538: HashTable, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator>::resize(unsigned long, unsigned long) @ 0x0000000014567d33 9. /build/src/Common/HashTable/HashTable.h:926: void DB::Aggregator::executeImplBatch, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, false, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x0000000014601e4b 10. /build/src/Interpreters/Aggregator.cpp:0: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, false, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x0000000014600040 11. /build/src/Interpreters/Aggregator.cpp:952: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>, true, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>, true, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x000000001452372f 12. /build/src/Interpreters/Aggregator.cpp:922: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x00000000144b3e5c 13. /build/src/Interpreters/Aggregator.cpp:1587: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x00000000144b7f40 14. /build/src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000016b170dc 15. /build/src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000016b14746 16. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 17. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 18. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000168d2a5e 19. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000168d34df 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 23. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 10. ? @ 0x00007f7210eb6ac3 11. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:21:25.015581 [ 37313 ] {afcfc070-f1e1-47de-8158-db669950a4d2} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00, current rows: 2.00. (TOO_MANY_ROWS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37316) (comment: 01505_trivial_count_with_partition_predicate.sql) (query 22, line 38) (in query: -- non-optimized select count() from test_tuple array join [p,p] as c where toDate(p) = '2020-09-01';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000013af9d2b 4. /build/src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013af96d2 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x0000000016d41675 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d56e9c 7. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016cf6870 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:21:25.029786 [ 37313 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00, current rows: 2.00. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000013af9d2b 4. /build/src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013af96d2 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x0000000016d41675 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d56e9c 7. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016cf6870 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:21:26.479661 [ 37313 ] {433883b1-f29b-4443-9820-dd10378fb53f} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00, current rows: 2.00. (TOO_MANY_ROWS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37316) (comment: 01505_trivial_count_with_partition_predicate.sql) (query 24, line 41) (in query: -- non-optimized select count() from test_tuple array join [1,2,3] as c where toDate(p) = '2020-09-01';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000013af9d2b 4. /build/src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013af96d2 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x0000000016d41675 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d56e9c 7. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016cf6870 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:21:26.530964 [ 37313 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00, current rows: 2.00. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000013af9d2b 4. /build/src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013af96d2 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x0000000016d41675 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d56e9c 7. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016cf6870 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:21:26.594494 [ 50141 ] {7582caa5-8093-4393-965f-ed5f447f13aa} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 136. Bytes expected: 1919379265.: In scope SELECT finalizeAggregation(CAST('AggregateFunction(categoricalInformationValue, Nullable(UInt8), UInt8)AggregateFunction(categoricalInformationValue, Nullable(UInt8), UInt8)', 'AggregateFunction(min, String)')). (CANNOT_READ_ALL_DATA) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:58348) (comment: 02481_i43247_ubsan_in_minmaxany.sql) (query 1, line 1) (in query: -- https://github.com/ClickHouse/ClickHouse/issues/43247 SELECT finalizeAggregation(CAST('AggregateFunction(categoricalInformationValue, Nullable(UInt8), UInt8)AggregateFunction(categoricalInformationValue, Nullable(UInt8), UInt8)', 'AggregateFunction(min, String)'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000b97110b 4. /build/src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000fb793e7 5. /build/src/AggregateFunctions/SingleValueData.cpp:0: DB::SingleValueDataString::read(DB::ReadBuffer&, DB::ISerialization const&, DB::Arena*) @ 0x000000001090a14d 6. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000013ba5e3e 7. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013ba609e 8. /build/src/Functions/FunctionsConversion.h:1922: DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x0000000012cd3b4b 9. /build/src/Functions/FunctionsConversion.h:1894: DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000012cd266d 10. /build/src/Functions/FunctionsConversion.h:3821: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000012e80e81 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012cc745b 12. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fc534a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 16. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f75b 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 27. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 28. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 2025.07.13 02:21:26.865179 [ 50141 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 136. Bytes expected: 1919379265.: In scope SELECT finalizeAggregation(CAST('AggregateFunction(categoricalInformationValue, Nullable(UInt8), UInt8)AggregateFunction(categoricalInformationValue, Nullable(UInt8), UInt8)', 'AggregateFunction(min, String)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000b97110b 4. /build/src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000fb793e7 5. /build/src/AggregateFunctions/SingleValueData.cpp:0: DB::SingleValueDataString::read(DB::ReadBuffer&, DB::ISerialization const&, DB::Arena*) @ 0x000000001090a14d 6. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000013ba5e3e 7. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013ba609e 8. /build/src/Functions/FunctionsConversion.h:1922: DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x0000000012cd3b4b 9. /build/src/Functions/FunctionsConversion.h:1894: DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000012cd266d 10. /build/src/Functions/FunctionsConversion.h:3821: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000012e80e81 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012cc745b 12. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009fc534a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e442 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7dfd8 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7e3ed 16. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c7f75b 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012c805b2 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f534f4 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f4ed1d 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f38ade 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 27. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 28. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 2025.07.13 02:21:27.371900 [ 12975 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:21:30.544974 [ 37313 ] {2e5d6d9d-9beb-49a0-9794-bce121341661} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00, current rows: 3.00. (TOO_MANY_ROWS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:37316) (comment: 01505_trivial_count_with_partition_predicate.sql) (query 29, line 51) (in query: -- non-optimized select count() from test_two_args where i = 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000013af9d2b 4. /build/src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013af96d2 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x0000000016d41675 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d56e9c 7. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016cf6870 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:21:30.602751 [ 37313 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00, current rows: 3.00. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000013af9d2b 4. /build/src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013af96d2 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x0000000016d41675 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d56e9c 7. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016cf6870 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014892fb4 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000014892d3e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 13. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 14. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:21:32.226521 [ 47960 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:21:33.792359 [ 32568 ] {6802aa90-3751-4e42-97ec-7b940ed17c8f} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 66897.586441 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40974) (comment: 02907_backup_mv_with_no_source_table.sh) (query 3, line 4) (in query: backup database test_13 on cluster test_shard_localhost to Disk('backups', '02907_backup_mv_with_no_source_table_test_132');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, unsigned long const&) @ 0x00000000144421ab 4. /build/src/Interpreters/ProcessList.cpp:519: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000001496a7fb 5. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x000000001496af0d 6. /build/src/Backups/BackupCoordinationStageSync.cpp:1178: DB::BackupCoordinationStageSync::checkIfOtherHostsFinish(String const&, std::optional>>, bool, bool&, bool) const @ 0x0000000013831912 7. /build/src/Backups/BackupCoordinationStageSync.cpp:1156: DB::BackupCoordinationStageSync::waitOtherHostsFinishImpl(String const&, std::optional>>, bool) const @ 0x0000000013831348 8. /build/src/Backups/BackupCoordinationStageSync.cpp:1125: DB::BackupCoordinationStageSync::waitOtherHostsFinish(bool) const @ 0x0000000013830bf6 9. /build/src/Backups/BackupsWorker.cpp:568: 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&) @ 0x00000000137ca56f 10. /build/src/Backups/BackupsWorker.cpp:418: DB::BackupsWorker::BackupStarter::doBackup() @ 0x00000000137d6570 11. /build/src/Backups/BackupsWorker.cpp:488: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&, std::shared_ptr const&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000137d246c 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013398524 13. /build/contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x0000000013398677 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 17. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:21:33.817869 [ 32568 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 66897.586441 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, unsigned long const&) @ 0x00000000144421ab 4. /build/src/Interpreters/ProcessList.cpp:519: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000001496a7fb 5. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x000000001496af0d 6. /build/src/Backups/BackupCoordinationStageSync.cpp:1178: DB::BackupCoordinationStageSync::checkIfOtherHostsFinish(String const&, std::optional>>, bool, bool&, bool) const @ 0x0000000013831912 7. /build/src/Backups/BackupCoordinationStageSync.cpp:1156: DB::BackupCoordinationStageSync::waitOtherHostsFinishImpl(String const&, std::optional>>, bool) const @ 0x0000000013831348 8. /build/src/Backups/BackupCoordinationStageSync.cpp:1125: DB::BackupCoordinationStageSync::waitOtherHostsFinish(bool) const @ 0x0000000013830bf6 9. /build/src/Backups/BackupsWorker.cpp:568: 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&) @ 0x00000000137ca56f 10. /build/src/Backups/BackupsWorker.cpp:418: DB::BackupsWorker::BackupStarter::doBackup() @ 0x00000000137d6570 11. /build/src/Backups/BackupsWorker.cpp:488: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&, std::shared_ptr const&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000137d246c 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013398524 13. /build/contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x0000000013398677 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 17. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x0000000013397daa 5. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:se190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x0000000013397bcf 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000137c888d 7. /build/src/Backups/BackupsWorker.cpp:334: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000137c86d7 8. /build/src/Interpreters/InterpreterBackupQuery.cpp:44: DB::InterpreterBackupQuery::execute() @ 0x0000000014c1cb1d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:21:38.017442 [ 11479 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:21:42.777328 [ 47956 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:21:43.058626 [ 4281 ] {224640a4-cb42-4c55-8b39-a140e54dc947::all_1_1_0_2} MutatePlainMergeTreeTask: 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)) 2025.07.13 02:21:43.081419 [ 4281 ] {224640a4-cb42-4c55-8b39-a140e54dc947::all_1_1_0_2} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 9. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000001494103a 7. /build/src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000016450695 8. /build/src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x000000001644fcf1 9. /build/src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x0000000016594cb8 10. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 11. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 13. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:21:43.083961 [ 4281 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {224640a4-cb42-4c55-8b39-a140e54dc947::all_1_1_0_2}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 9. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000001494103a 7. /build/src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000016450695 8. /build/src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x000000001644fcf1 9. /build/src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x0000000016594cb8 10. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 11. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 13. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 16. ? @ 0x00007f7210eb6ac3 17. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:21:43.167433 [ 4922 ] {edaf2ba3-b23d-4fe5-87a8-0415dbb47aec} executeQuery: Code: 341. DB::Exception: Mutation mutation_2.txt was killed. (UNFINISHED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39402) (comment: 01456_modify_column_type_via_add_drop_update.sql) (query 6, line 10) (in query: ALTER TABLE tbl UPDATE xi = a WHERE 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Storages/MergeTree/MergeTreeMutationStatus.cpp:22: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x000000001639b964 5. /build/src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000001655dce8 6. /build/src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000001655ed84 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd3ec 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:21:43.239436 [ 4922 ] {} TCPHandler: Code: 341. DB::Exception: Mutation mutation_2.txt was killed. (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Storages/MergeTree/MergeTreeMutationStatus.cpp:22: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x000000001639b964 5. /build/src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000001655dce8 6. /build/src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000001655ed84 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000147fd3ec 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000147fb08d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:21:48.171373 [ 47983 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:21:52.823073 [ 50432 ] {416bb0de-3120-4905-98ed-b15ebd25d296} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1436.471152 ms, maximum: 1000 ms. (TIMEOUT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:51794) (comment: 02293_http_header_summary_contains_exception_code_with_progress.sh) (in query: SELECT 1 + sleepEachRow(0.00002) FROM numbers(100000) ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, unsigned long const&) @ 0x00000000144421ab 4. /build/src/Interpreters/ProcessList.cpp:519: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000001496a7fb 5. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x000000001496af0d 6. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000168d1a5a 7. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0c24 8. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000168cfa64 9. /build/src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014bab0a3 10. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 11. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 12. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:21:52.849641 [ 50432 ] {416bb0de-3120-4905-98ed-b15ebd25d296} DynamicQueryHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1436.471152 ms, maximum: 1000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, unsigned long const&) @ 0x00000000144421ab 4. /build/src/Interpreters/ProcessList.cpp:519: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000001496a7fb 5. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x000000001496af0d 6. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000168d1a5a 7. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0c24 8. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000168cfa64 9. /build/src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014bab0a3 10. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 11. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 12. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:21:53.180716 [ 47965 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:21:54.367673 [ 51780 ] {d2a667d9-b642-4db1-ac60-9bd6a5f31771} 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]:47296) (comment: 02889_file_log_save_errors.sh) (in query: DROP DATABASE IF EXISTS test_lnju7vxg SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:21:54.430319 [ 51780 ] {d2a667d9-b642-4db1-ac60-9bd6a5f31771} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000014418219 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014835cfe 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014831cc8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014831482 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014830ea5 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:21:58.396756 [ 12987 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:21:59.187697 [ 47968 ] {6ffac74c-9009-41a0-aa17-20c6a8e0b92d} BackupsWorker: Failed to restore from backup Disk('backups', '02907_backup_mv_with_no_source_table_test_132'): Code: 599. DB::Exception: Backup Disk('backups', '02907_backup_mv_with_no_source_table_test_132') not found. (BACKUP_NOT_FOUND), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Backups/BackupImpl.cpp:429: DB::BackupImpl::readBackupMetadata() @ 0x00000000137e58ff 5. /build/src/Backups/BackupImpl.cpp:187: DB::BackupImpl::open() @ 0x00000000137e2087 6. /build/src/Backups/BackupImpl.cpp:112: DB::BackupImpl::BackupImpl(DB::BackupFactory::CreateParams, DB::BackupImpl::ArchiveParams const&, std::shared_ptr, std::shared_ptr) @ 0x00000000137e168a 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::registerBackupEnginesFileAndDisk(DB::BackupFactory&)::$_0::operator()(DB::BackupFactory::CreateParams const&) const @ 0x0000000013879776 8. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl[abi:se190107] (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000013877e6d 9. /build/src/Backups/BackupsWorker.cpp:874: DB::BackupsWorker::openBackupForReading(DB::BackupInfo const&, DB::RestoreSettings const&, std::shared_ptr const&) const @ 0x00000000137cd0df 10. /build/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&) @ 0x00000000137cd8e9 11. /build/src/Backups/BackupsWorker.cpp:793: DB::BackupsWorker::RestoreStarter::doRestore() @ 0x00000000137d8105 12. /build/src/Backups/BackupsWorker.cpp:840: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&, std::shared_ptr)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000137d260c 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013398524 14. /build/contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x0000000013398677 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 18. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x0000000013397daa 5. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:se190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x0000000013397bcf 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000137c8ba2 7. /build/src/Backups/BackupsWorker.cpp:335: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000137c866d 8. /build/src/Interpreters/InterpreterBackupQuery.cpp:44: DB::InterpreterBackupQuery::execute() @ 0x0000000014c1cb1d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:22:03.221415 [ 47952 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:22:06.504954 [ 50005 ] {7faa288c-56ef-4d9e-85a6-2760e6bf3171} executeQuery: Code: 57. DB::Exception: Table test_fih1rgd1.test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:44652) (comment: 03039_dynamic_versioned_collapsing_merge_tree.sh) (query 1, line 1) (in query: CREATE TABLE test (`id` UInt64, `sign` Int8, `version` UInt8, `d` Dynamic) ENGINE = VersionedCollapsingMergeTree(sign, version) ORDER BY id SETTINGS min_rows_for_wide_part = 1, min_bytes_for_wide_part = 1, index_granularity = 8128, 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 = 439113304, compact_parts_max_bytes_to_buffer = 252203271, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 18660714, merge_max_block_size = 8128, old_parts_lifetime = 114., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 298622, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 7069088574, index_granularity_bytes = 10485760, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 82376, primary_key_compress_block_size = 66214, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:22:06.546522 [ 50005 ] {} TCPHandler: Code: 57. DB::Exception: Table test_fih1rgd1.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000148200bb 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000014818029 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d81 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:22:08.680321 [ 40080 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:22:11.979909 [ 49744 ] {6ffac74c-9009-41a0-aa17-20c6a8e0b92d} executeQuery: Code: 599. DB::Exception: Backup Disk('backups', '02907_backup_mv_with_no_source_table_test_132') not found. (BACKUP_NOT_FOUND) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39410) (comment: 02907_backup_mv_with_no_source_table.sh) (query 3, line 4) (in query: restore table test_13.mv on cluster test_shard_localhost from Disk('backups', '02907_backup_mv_with_no_source_table_test_132');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Backups/BackupImpl.cpp:429: DB::BackupImpl::readBackupMetadata() @ 0x00000000137e58ff 5. /build/src/Backups/BackupImpl.cpp:187: DB::BackupImpl::open() @ 0x00000000137e2087 6. /build/src/Backups/BackupImpl.cpp:112: DB::BackupImpl::BackupImpl(DB::BackupFactory::CreateParams, DB::BackupImpl::ArchiveParams const&, std::shared_ptr, std::shared_ptr) @ 0x00000000137e168a 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::registerBackupEnginesFileAndDisk(DB::BackupFactory&)::$_0::operator()(DB::BackupFactory::CreateParams const&) const @ 0x0000000013879776 8. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl[abi:se190107] (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000013877e6d 9. /build/src/Backups/BackupsWorker.cpp:874: DB::BackupsWorker::openBackupForReading(DB::BackupInfo const&, DB::RestoreSettings const&, std::shared_ptr const&) const @ 0x00000000137cd0df 10. /build/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&) @ 0x00000000137cd8e9 11. /build/src/Backups/BackupsWorker.cpp:793: DB::BackupsWorker::RestoreStarter::doRestore() @ 0x00000000137d8105 12. /build/src/Backups/BackupsWorker.cpp:840: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&, std::shared_ptr)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000137d260c 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013398524 14. /build/contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x0000000013398677 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 18. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 2025.07.13 02:22:12.082422 [ 49744 ] {} TCPHandler: Code: 599. DB::Exception: Backup Disk('backups', '02907_backup_mv_with_no_source_table_test_132') not found. (BACKUP_NOT_FOUND), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Backups/BackupImpl.cpp:429: DB::BackupImpl::readBackupMetadata() @ 0x00000000137e58ff 5. /build/src/Backups/BackupImpl.cpp:187: DB::BackupImpl::open() @ 0x00000000137e2087 6. /build/src/Backups/BackupImpl.cpp:112: DB::BackupImpl::BackupImpl(DB::BackupFactory::CreateParams, DB::BackupImpl::ArchiveParams const&, std::shared_ptr, std::shared_ptr) @ 0x00000000137e168a 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::registerBackupEnginesFileAndDisk(DB::BackupFactory&)::$_0::operator()(DB::BackupFactory::CreateParams const&) const @ 0x0000000013879776 8. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl[abi:se190107] (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000013877e6d 9. /build/src/Backups/BackupsWorker.cpp:874: DB::BackupsWorker::openBackupForReading(DB::BackupInfo const&, DB::RestoreSettings const&, std::shared_ptr const&) const @ 0x00000000137cd0df 10. /build/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&) @ 0x00000000137cd8e9 11. /build/src/Backups/BackupsWorker.cpp:793: DB::BackupsWorker::RestoreStarter::doRestore() @ 0x00000000137d8105 12. /build/src/Backups/BackupsWorker.cpp:840: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&, std::shared_ptr)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000137d260c 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013398524 14. /build/contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x0000000013398677 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 18. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 19. ? @ 0x00007f7210eb6ac3 20. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda43c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 4. /build/src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x0000000013397daa 5. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:se190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x0000000013397bcf 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000137c8ba2 7. /build/src/Backups/BackupsWorker.cpp:335: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000137c866d 8. /build/src/Interpreters/InterpreterBackupQuery.cpp:44: DB::InterpreterBackupQuery::execute() @ 0x0000000014c1cb1d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 11. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 12. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 17. ? @ 0x00007f7210eb6ac3 18. ? @ 0x00007f7210f48850 2025.07.13 02:22:14.012620 [ 5822 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:22:14.708357 [ 4270 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {e5868042-e7c6-4840-b138-5ed55dc8d3ee::202507_125_135_2}: Code: 241. DB::Exception: Thread memory tracker: fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000000fb2dc4b 4. /build/src/Common/MemoryTracker.cpp:196: MemoryTracker::injectFault() const @ 0x000000000fb2b6cd 5. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:153: DB::MergePlainMergeTreeTask::finish() @ 0x0000000016593639 6. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:72: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000016592af2 7. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 8. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:22:15.083327 [ 4281 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {33aa6152-b82f-4ea0-b9aa-74960d6415ef::202507_1_148_36}: Code: 241. DB::Exception: Thread memory tracker: fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000000fb2dc4b 4. /build/src/Common/MemoryTracker.cpp:196: MemoryTracker::injectFault() const @ 0x000000000fb2b6cd 5. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:153: DB::MergePlainMergeTreeTask::finish() @ 0x0000000016593639 6. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:72: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000016592af2 7. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 8. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:22:18.522230 [ 40065 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:22:23.728147 [ 47964 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:22:28.717631 [ 39962 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:22:31.085904 [ 50320 ] {f0bbd2db-ac7e-49c1-8bc3-42ac8512065e} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 60062.405243 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:39390) (comment: 02834_apache_arrow_abort.sql) (query 2, line 4) (in query: INSERT INTO TABLE FUNCTION url('https://clickhouse-public-datasets.s3.amazonaws.com/hits_compatible/athena_partitioned/hits_9.parquet') SELECT * FROM url('https://clickhouse-public-datasets.s3.amazonaws.com/hits_compatible/athena_partitioned/hits_9.parquet');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x0000000013ad84ab 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x0000000013ad77ec 5. /build/src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x000000001496af1f 6. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000168d1a5a 7. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0c24 8. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168cfe81 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 2025.07.13 02:22:31.617684 [ 50320 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 60062.405243 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x0000000013ad84ab 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x0000000013ad77ec 5. /build/src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x000000001496af1f 6. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000168d1a5a 7. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0c24 8. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168cfe81 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x00000000168cf907 5. /build/src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000001680710e 6. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 2025.07.13 02:22:31.912809 [ 5121 ] {3a447fe5-ee53-4cff-9e14-7e1d1cf035c1} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.4]:9000 -> [::ffff:127.0.0.1]:42858). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fc62e75 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fc642b1 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x0000000009fb95be 5. /build/src/Server/TCPHandler.cpp:823: DB::TCPHandler::runImpl() @ 0x0000000016807266 6. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:22:33.722340 [ 4858 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:22:38.695902 [ 40065 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:22:43.782692 [ 11482 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:22:48.862993 [ 47963 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:22:51.169916 [ 6162 ] {09403f36-4830-4c4d-80b5-f1ca87308a70} executeQuery: Code: 159. DB::Exception: Timeout exceeded (180 s) while flushing system log 'DB::SystemLogQueue'. (TIMEOUT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:51500) (comment: 03143_prewhere_profile_events.sh) (query 1, line 2) (in query: SYSTEM FLUSH LOGS;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Common/SystemLogBase.cpp:168: DB::SystemLogQueue::waitFlush(long, bool) @ 0x000000000fbee407 5. /build/src/Interpreters/SystemLog.cpp:437: DB::SystemLogs::flush(bool, std::vector> const&) @ 0x0000000014a1ea9f 6. /build/src/Interpreters/InterpreterSystemQuery.cpp:796: DB::InterpreterSystemQuery::execute() @ 0x0000000014bd5a4e 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:22:51.187989 [ 6162 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded (180 s) while flushing system log 'DB::SystemLogQueue'. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Common/SystemLogBase.cpp:168: DB::SystemLogQueue::waitFlush(long, bool) @ 0x000000000fbee407 5. /build/src/Interpreters/SystemLog.cpp:437: DB::SystemLogs::flush(bool, std::vector> const&) @ 0x0000000014a1ea9f 6. /build/src/Interpreters/InterpreterSystemQuery.cpp:796: DB::InterpreterSystemQuery::execute() @ 0x0000000014bd5a4e 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:22:53.935591 [ 40061 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:22:58.920304 [ 47968 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:22:58.923648 [ 47982 ] {} ExternalDictionariesLoader: Could not load external dictionary '0ca1414e-e1b1-4e07-bc23-aa654781fa7d', next update is scheduled at 2025-07-13 02:23:30: Code: 36. DB::Exception: 0ca1414e-e1b1-4e07-bc23-aa654781fa7d: SHARDS parameter does not supports for updatable source (UPDATE_FIELD). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Dictionaries/registerHashedDictionary.cpp:89: DB::registerDictionaryHashed(DB::DictionaryFactory&)::$_4::operator()(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, DB::DictionaryKeyType, bool) const @ 0x0000000011c50410 5. /build/src/Dictionaries/registerHashedDictionary.cpp:127: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:se190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x0000000011c509d9 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012c74f5d 7. /build/src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000147cade4 8. /build/src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000147d6c48 9. /build/src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000147d56dd 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000147d96f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:23:03.954360 [ 47958 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:23:04.322548 [ 47958 ] {} ExternalDictionariesLoader: Could not update external dictionary 'd6fbfd16-05c4-4288-b325-142078f64329', leaving the previous version, next update is scheduled at 2025-07-13 02:23:10: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=33, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x00000000163993d1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016396620 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001639641f 10. /build/src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000163b2bd7 11. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x00000000162ea22d 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x00000000162e6974 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x00000000163d9ded 14. /build/src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x0000000016d7885f 15. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x0000000016d9cdca 16. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x00000000163e5520 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016d68aa9 18. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000168c29e7 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000168dd6af 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000168d27a5 21. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000168d1d47 22. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000168e0ebc 23. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000168e1018 24. /build/src/Dictionaries/HashedDictionary.h:1167: DB::HashedDictionary<(DB::DictionaryKeyType)1, false, false>::loadData() @ 0x0000000011e1a910 25. /build/src/Dictionaries/HashedDictionary.h:312: DB::HashedDictionary<(DB::DictionaryKeyType)1, false, false>::HashedDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::HashedDictionaryConfiguration const&, std::shared_ptr) @ 0x0000000011e1a217 26. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr> std::allocate_shared[abi:se190107], std::allocator>, DB::StorageID, DB::DictionaryStructure const&, std::shared_ptr, DB::HashedDictionaryConfiguration const&, std::shared_ptr const&, 0>(std::allocator> const&, DB::StorageID&&, DB::DictionaryStructure const&, std::shared_ptr&&, DB::HashedDictionaryConfiguration const&, std::shared_ptr const&) @ 0x0000000011f3c828 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::HashedDictionary<(DB::DictionaryKeyType)1, false, false>::clone() const @ 0x0000000011e1b59f 28. /build/src/Interpreters/ExternalLoader.cpp:1510: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000147d6c14 29. /build/src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000147d56dd 30. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000147d96f4 31. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:23:07.324387 [ 4887 ] {fc14fb98-c672-47fe-adc2-c5667565110e} executeQuery: Code: 159. DB::Exception: Timeout exceeded (180 s) while flushing system log 'DB::SystemLogQueue'. (TIMEOUT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:42256) (comment: 03277_logging_elapsed_ns.sql) (query 2, line 3) (in query: SYSTEM FLUSH LOGS;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Common/SystemLogBase.cpp:168: DB::SystemLogQueue::waitFlush(long, bool) @ 0x000000000fbee407 5. /build/src/Interpreters/SystemLog.cpp:437: DB::SystemLogs::flush(bool, std::vector> const&) @ 0x0000000014a1ea9f 6. /build/src/Interpreters/InterpreterSystemQuery.cpp:796: DB::InterpreterSystemQuery::execute() @ 0x0000000014bd5a4e 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:23:07.343524 [ 4887 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded (180 s) while flushing system log 'DB::SystemLogQueue'. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Common/SystemLogBase.cpp:168: DB::SystemLogQueue::waitFlush(long, bool) @ 0x000000000fbee407 5. /build/src/Interpreters/SystemLog.cpp:437: DB::SystemLogs::flush(bool, std::vector> const&) @ 0x0000000014a1ea9f 6. /build/src/Interpreters/InterpreterSystemQuery.cpp:796: DB::InterpreterSystemQuery::execute() @ 0x0000000014bd5a4e 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:23:14.077424 [ 12992 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:23:19.030403 [ 47983 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:23:24.210667 [ 47960 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:23:29.192785 [ 39724 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:23:34.247124 [ 47963 ] {} ExternalDictionariesLoader: Could not load external dictionary '02ea2b3a-7cb3-4b74-abb1-4f80305a92a9', next update is scheduled at 2025-07-13 02:29:03: Code: 482. DB::Exception: Dictionaries with executable dictionary source are not allowed to be created from DDL query. (DICTIONARY_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Dictionaries/ExecutableDictionarySource.cpp:233: std::shared_ptr std::__function::__policy_invoker (DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr, String const&, bool)>::__call_impl[abi:se190107] (DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr, String const&, bool)>>(std::__function::__policy_storage const*, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr&&, String const&, bool) @ 0x00000000119c8c6b 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012c76e33 6. /build/src/Dictionaries/DictionaryFactory.cpp:47: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x0000000012c74a2d 7. /build/src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000147cade4 8. /build/src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000147d6c48 9. /build/src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000147d56dd 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000147d96f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:23:34.327362 [ 47967 ] {} ExternalDictionariesLoader: Could not load external dictionary '0ca1414e-e1b1-4e07-bc23-aa654781fa7d', next update is scheduled at 2025-07-13 02:26:02: Code: 36. DB::Exception: 0ca1414e-e1b1-4e07-bc23-aa654781fa7d: SHARDS parameter does not supports for updatable source (UPDATE_FIELD). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Dictionaries/registerHashedDictionary.cpp:89: DB::registerDictionaryHashed(DB::DictionaryFactory&)::$_4::operator()(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, DB::DictionaryKeyType, bool) const @ 0x0000000011c50410 5. /build/src/Dictionaries/registerHashedDictionary.cpp:127: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:se190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x0000000011c509d9 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012c74f5d 7. /build/src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000147cade4 8. /build/src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000147d6c48 9. /build/src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000147d56dd 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000147d96f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:23:34.337472 [ 40079 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:23:39.394537 [ 6027 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:23:39.574420 [ 6027 ] {} ExternalDictionariesLoader: Could not update external dictionary 'd6fbfd16-05c4-4288-b325-142078f64329', leaving the previous version, next update is scheduled at 2025-07-13 02:23:45: 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000168d32ac 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000168d1247 9. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0a94 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:23:49.483286 [ 5822 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:23:54.679742 [ 5071 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:23:59.637570 [ 39959 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:24:04.691829 [ 5085 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:24:09.697494 [ 47971 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:24:14.740167 [ 47972 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:24:19.776899 [ 47968 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:24:24.830503 [ 5086 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:24:29.844405 [ 47969 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:24:35.031463 [ 40064 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:24:40.181113 [ 11482 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:24:45.164999 [ 47963 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:24:46.037521 [ 50016 ] {f379dec0-67bf-4116-89cd-792bb7a706f6} executeQuery: Code: 159. DB::Exception: Timeout exceeded (180 s) while flushing system log 'DB::SystemLogQueue'. (TIMEOUT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:40600) (comment: 03326_parallel_replicas_out_of_range.sql) (query 2, line 6) (in query: SYSTEM FLUSH LOGS;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Common/SystemLogBase.cpp:168: DB::SystemLogQueue::waitFlush(long, bool) @ 0x000000000fbee407 5. /build/src/Interpreters/SystemLog.cpp:437: DB::SystemLogs::flush(bool, std::vector> const&) @ 0x0000000014a1ea9f 6. /build/src/Interpreters/InterpreterSystemQuery.cpp:796: DB::InterpreterSystemQuery::execute() @ 0x0000000014bd5a4e 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:24:46.070184 [ 50016 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded (180 s) while flushing system log 'DB::SystemLogQueue'. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000009fae8eb 4. /build/src/Common/SystemLogBase.cpp:168: DB::SystemLogQueue::waitFlush(long, bool) @ 0x000000000fbee407 5. /build/src/Interpreters/SystemLog.cpp:437: DB::SystemLogs::flush(bool, std::vector> const&) @ 0x0000000014a1ea9f 6. /build/src/Interpreters/InterpreterSystemQuery.cpp:796: DB::InterpreterSystemQuery::execute() @ 0x0000000014bd5a4e 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 9. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 10. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 15. ? @ 0x00007f7210eb6ac3 16. ? @ 0x00007f7210f48850 2025.07.13 02:24:50.432818 [ 12991 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:24:55.291362 [ 39696 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:25:00.274521 [ 47958 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:25:02.529110 [ 4267 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {3942dd54-929b-4ad9-a2fe-0ea015f8ba1e::202507_118_167_22}: Code: 241. DB::Exception: Thread memory tracker: fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000000fb2dc4b 4. /build/src/Common/MemoryTracker.cpp:196: MemoryTracker::injectFault() const @ 0x000000000fb2b6cd 5. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:153: DB::MergePlainMergeTreeTask::finish() @ 0x0000000016593639 6. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:72: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000016592af2 7. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 8. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:25:05.357390 [ 47970 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:25:10.349723 [ 47951 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:25:15.396052 [ 47957 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:25:20.492366 [ 39963 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:25:25.539195 [ 11479 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:25:30.614814 [ 40079 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:25:35.670725 [ 39696 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:25:40.767610 [ 39961 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:25:45.794091 [ 12987 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:25:49.047506 [ 4283 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {e3530006-7dd9-48ab-80f5-3cf9bb92d43a::202507_1_157_37}: Code: 241. DB::Exception: Thread memory tracker: fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000000fb2dc4b 4. /build/src/Common/MemoryTracker.cpp:196: MemoryTracker::injectFault() const @ 0x000000000fb2b6cd 5. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:153: DB::MergePlainMergeTreeTask::finish() @ 0x0000000016593639 6. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:72: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000016592af2 7. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 8. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:25:50.819386 [ 47983 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:25:56.062291 [ 47961 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:26:00.958488 [ 40080 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:26:01.053342 [ 3552 ] {} CgroupsReader: Cannot find 'kernel' in '/sys/fs/cgroup/memory.stat' (skipped 5778 similar messages) 2025.07.13 02:26:06.025483 [ 47965 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:26:06.059261 [ 47982 ] {} ExternalDictionariesLoader: Could not load external dictionary '0ca1414e-e1b1-4e07-bc23-aa654781fa7d', next update is scheduled at 2025-07-13 02:36:06: Code: 36. DB::Exception: 0ca1414e-e1b1-4e07-bc23-aa654781fa7d: SHARDS parameter does not supports for updatable source (UPDATE_FIELD). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a8cc3cb 4. /build/src/Dictionaries/registerHashedDictionary.cpp:89: DB::registerDictionaryHashed(DB::DictionaryFactory&)::$_4::operator()(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, DB::DictionaryKeyType, bool) const @ 0x0000000011c50410 5. /build/src/Dictionaries/registerHashedDictionary.cpp:127: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:se190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x0000000011c509d9 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012c74f5d 7. /build/src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000147cade4 8. /build/src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000147d6c48 9. /build/src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000147d56dd 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000147d96f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:26:11.090319 [ 5821 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:26:16.144959 [ 12972 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:26:21.178891 [ 11496 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:26:26.192274 [ 5081 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:26:31.214780 [ 40064 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:26:36.399126 [ 5989 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:26:41.388449 [ 39957 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:26:46.497728 [ 47986 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:26:51.488536 [ 4858 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:26:56.541666 [ 39696 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:27:01.536469 [ 5071 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:27:06.595951 [ 12973 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:27:11.693228 [ 47952 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:27:16.657645 [ 40061 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:27:21.705708 [ 39963 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:27:26.875195 [ 10910 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:27:31.777103 [ 47968 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:27:36.800795 [ 39696 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:27:41.927508 [ 5071 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:27:46.933454 [ 4283 ] {79e989a3-28e6-4868-84fc-6251e7368e89::202507_268_343_15} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=33, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x00000000163993d1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016396620 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001639641f 10. /build/src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000163b2bd7 11. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x00000000162ea22d 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x00000000162e6974 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x00000000163d9d66 14. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:159: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::Block, DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr, std::shared_ptr, std::optional, bool, bool) @ 0x00000000163d3337 15. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:se190107] const&, std::shared_ptr, std::optional, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x00000000163d9212 16. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x00000000163d553a 17. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:383: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000163d7ceb 18. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016cf6870 19. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 20. /build/src/Storages/MergeTree/MergeTask.cpp:1910: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() const @ 0x00000000161f8487 21. /build/src/Storages/MergeTree/MergeTask.cpp:567: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000161f2613 22. /build/src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000161f9939 23. /build/src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000161ffd8a 24. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000016592b05 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 26. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 28. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 30. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 31. ? @ 0x00007f7210eb6ac3 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:27:46.938077 [ 4283 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {79e989a3-28e6-4868-84fc-6251e7368e89::202507_268_343_15}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=33, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fbdd40b 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fbded33 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbda0dc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fbd9f2e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x00000000163993d1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016396620 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001639641f 10. /build/src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000163b2bd7 11. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x00000000162ea22d 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x00000000162e6974 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x00000000163d9d66 14. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:159: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::Block, DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr, std::shared_ptr, std::optional, bool, bool) @ 0x00000000163d3337 15. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:se190107] const&, std::shared_ptr, std::optional, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x00000000163d9212 16. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x00000000163d553a 17. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:383: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000163d7ceb 18. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016cf6870 19. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016d25e6f 20. /build/src/Storages/MergeTree/MergeTask.cpp:1910: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() const @ 0x00000000161f8487 21. /build/src/Storages/MergeTree/MergeTask.cpp:567: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000161f2613 22. /build/src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000161f9939 23. /build/src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000161ffd8a 24. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000016592b05 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162206b0 26. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000016220ff3 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd8b73 28. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fbde9e2 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 30. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 31. ? @ 0x00007f7210eb6ac3 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:27:47.016132 [ 47967 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:27:52.070438 [ 5989 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:27:57.196310 [ 47956 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:28:02.188165 [ 5991 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:28:07.184974 [ 39961 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:28:12.301763 [ 40065 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:28:17.360013 [ 47959 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:28:22.357672 [ 47951 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:28:27.397525 [ 39962 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:28:32.442730 [ 47963 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:28:37.475366 [ 47972 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:28:42.626577 [ 6027 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:28:47.566528 [ 5086 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:28:52.612808 [ 40065 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:28:57.680078 [ 12975 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:29:02.796283 [ 47964 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:29:07.685198 [ 40080 ] {} ExternalDictionariesLoader: Could not load external dictionary '02ea2b3a-7cb3-4b74-abb1-4f80305a92a9', next update is scheduled at 2025-07-13 02:38:59: Code: 482. DB::Exception: Dictionaries with executable dictionary source are not allowed to be created from DDL query. (DICTIONARY_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000009fb8fcb 4. /build/src/Dictionaries/ExecutableDictionarySource.cpp:233: std::shared_ptr std::__function::__policy_invoker (DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr, String const&, bool)>::__call_impl[abi:se190107] (DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr, String const&, bool)>>(std::__function::__policy_storage const*, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr&&, String const&, bool) @ 0x00000000119c8c6b 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012c76e33 6. /build/src/Dictionaries/DictionaryFactory.cpp:47: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x0000000012c74a2d 7. /build/src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000147cade4 8. /build/src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000147d6c48 9. /build/src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000147d56dd 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000147d96f4 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:29:07.735957 [ 47982 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:29:12.857228 [ 47963 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:29:17.808434 [ 11007 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:29:22.754138 [ 40065 ] {} Aggregator: No system memory limits configured. Ignoring max_bytes_ratio_before_external_group_by 2025.07.13 02:29:23.480599 [ 5015 ] {085203a5-ad14-40d4-86f6-739c6a318ab8} executeQuery: Code: 36. DB::Exception: Query tree is too big. Maximum: 500000. (BAD_ARGUMENTS) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:36978) (comment: 00596_limit_on_expanded_ast.sh) (query 1, line 2) (in query: select 1 as a, a+a as b, b+b as c, c+c as d, d+d as e, e+e as f, f+f as g, g+g as h, h+h as i, i+i as j, j+j as k, k+k as l, l+l as m, m+m as n, n+n as o, o+o as p, p+p as q, q+q as r, r+r as s, s+s as t, t+t as u, u+u as v, v+v as w, w+w as x, x+x as y, y+y as z ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000b152a4b 4. /build/src/Analyzer/ValidationUtils.cpp:478: DB::validateTreeSize(std::shared_ptr const&, unsigned long, std::unordered_map, unsigned long, std::hash>, std::equal_to>, std::allocator const, unsigned long>>>&) @ 0x0000000013f8767c 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3919: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f39f0a 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 16. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:29:23.481216 [ 5015 ] {085203a5-ad14-40d4-86f6-739c6a318ab8} 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]:36978). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fc62e75 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fc64467 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x0000000009fb95be 5. /build/src/Server/TCPHandler.cpp:825: DB::TCPHandler::runImpl() @ 0x000000001680727c 6. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:29:23.481293 [ 5015 ] {} TCPHandler: Code: 36. DB::Exception: Query tree is too big. Maximum: 500000. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000b152a4b 4. /build/src/Analyzer/ValidationUtils.cpp:478: DB::validateTreeSize(std::shared_ptr const&, unsigned long, std::unordered_map, unsigned long, std::hash>, std::equal_to>, std::allocator const, unsigned long>>>&) @ 0x0000000013f8767c 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3919: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000013f39f0a 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000013f37e71 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000013f62007 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000013f3215e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000013f31219 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000013f30a70 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000013f8baaa 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000148924c2 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001489100d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000148936c4 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001484762b 16. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba65c1 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014ba280b 18. /build/src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x0000000016806d81 19. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 24. ? @ 0x00007f7210eb6ac3 25. ? @ 0x00007f7210f48850 2025.07.13 02:30:23.230766 [ 56823 ] {68ab099d-27aa-4468-baec-d192d249a81e} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 60077.289521 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED) (version 25.3.3.20372.altinityantalya (altinity build)) (from [::1]:54882) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x0000000013ad84ab 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x0000000013ad77ec 5. /build/src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x000000001496af1f 6. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000168d1a5a 7. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0c24 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 2025.07.13 02:30:23.231221 [ 56823 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 60077.289521 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x0000000013ad84ab 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x0000000013ad77ec 5. /build/src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x000000001496af1f 6. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000168d1a5a 7. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000168d0c24 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000168e054c 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fbd62b2 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fbdc5a0 11. ? @ 0x00007f7210eb6ac3 12. ? @ 0x00007f7210f48850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fb46f64 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fbd53c7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fbd787c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fbd7d6d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000168df833 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000168dfbb8 6. /build/src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x0000000016811b05 7. /build/src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x0000000016806ec5 8. /build/src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000001681eef9 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 13. ? @ 0x00007f7210eb6ac3 14. ? @ 0x00007f7210f48850 2025.07.13 02:30:23.839215 [ 50432 ] {1f1d01db-02d6-488e-bcb4-dc71d99cd7db} 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]:34654) (in query: CREATE DATABASE IF NOT EXISTS test ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:216: DB::ErrnoException::ErrnoException(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000013c846ce 4. /build/src/Common/atomicRename.cpp:94: DB::renameat2(String const&, String const&, int) @ 0x0000000013c844e4 5. /build/src/Common/atomicRename.cpp:227: DB::renameNoReplace(String const&, String const&) @ 0x0000000013c8409a 6. /build/src/Disks/DiskLocal.cpp:318: DB::DiskLocal::moveFile(String const&, String const&) @ 0x0000000013dd2a7e 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:395: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148076a1 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 2025.07.13 02:30:23.839789 [ 50432 ] {1f1d01db-02d6-488e-bcb4-dc71d99cd7db} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:216: DB::ErrnoException::ErrnoException(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000013c846ce 4. /build/src/Common/atomicRename.cpp:94: DB::renameat2(String const&, String const&, int) @ 0x0000000013c844e4 5. /build/src/Common/atomicRename.cpp:227: DB::renameNoReplace(String const&, String const&) @ 0x0000000013c8409a 6. /build/src/Disks/DiskLocal.cpp:318: DB::DiskLocal::moveFile(String const&, String const&) @ 0x0000000013dd2a7e 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:395: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148076a1 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x0000000014823d7a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014ba6d49 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014baa9fb 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001678dbd2 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000167909c7 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016828479 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ab87e47 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ab8831e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ab35992 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ab335cf 18. ? @ 0x00007f7210eb6ac3 19. ? @ 0x00007f7210f48850 (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:30:27.935306 [ 3534 ] {} Application: Closed all listening sockets. Waiting for 26 outstanding connections. 2025.07.13 02:30:32.841403 [ 3534 ] {} Application: Closed connections. But 26 remain. Tip: To increase wait time add to config: 60 2025.07.13 02:30:32.841522 [ 3534 ] {} Application: Will shutdown forcefully. 2025.07.13 02:30:34.495317 [ 56926 ] {} Context: Server was built in debug mode. It will work slowly. 2025.07.13 02:30:34.966071 [ 56944 ] {} CgroupsReader: Cannot find 'kernel' in '/sys/fs/cgroup/memory.stat' 2025.07.13 02:30:35.276073 [ 56926 ] {} 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:30:35.281678 [ 56926 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.07.13 02:30:35.281699 [ 56926 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.07.13 02:30:35.332835 [ 57522 ] {} RaftInstance: Election timeout, initiate leader election 2025.07.13 02:30:35.431097 [ 56926 ] {} Context: Server logging level is set to 'test' and performance is degraded. This cannot be used in production. 2025.07.13 02:30:35.431829 [ 56926 ] {} 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:30:35.432444 [ 56926 ] {} 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:30:45.340852 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_exkv6e86.sql.tmp 2025.07.13 02:30:45.341045 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_rgzw8qds.sql.tmp 2025.07.13 02:30:45.341122 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_ynuzmutz.sql.tmp 2025.07.13 02:30:45.341214 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_m7pcv99y.sql.tmp 2025.07.13 02:30:45.341276 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_35trfx75.sql.tmp 2025.07.13 02:30:45.341329 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_reczqsjd.sql.tmp 2025.07.13 02:30:45.341385 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_uxcgr276.sql.tmp 2025.07.13 02:30:45.341435 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_uuhtc9yz.sql.tmp 2025.07.13 02:30:45.341495 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_zoyfhbed.sql.tmp 2025.07.13 02:30:45.341564 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_3781bewc.sql.tmp 2025.07.13 02:30:45.341614 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_j72tbjkl.sql.tmp 2025.07.13 02:30:45.341665 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_rwmy9m03.sql.tmp 2025.07.13 02:30:45.341749 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_77tyzpfg.sql.tmp 2025.07.13 02:30:45.341813 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_772khzx2.sql.tmp 2025.07.13 02:30:45.341866 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_6g1yk2cm.sql.tmp 2025.07.13 02:30:45.341928 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_t4apymc4.sql.tmp 2025.07.13 02:30:45.341993 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_zm0soxxm.sql.tmp 2025.07.13 02:30:45.342043 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_mz455pbn.sql.tmp 2025.07.13 02:30:45.342139 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_6sa0jh7x.sql.tmp 2025.07.13 02:30:45.342214 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_1rafv9qs.sql.tmp 2025.07.13 02:30:45.342264 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_abpl6d7s.sql.tmp 2025.07.13 02:30:45.342319 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_n1qlgptd.sql.tmp 2025.07.13 02:30:45.342370 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_kolfuu19.sql.tmp 2025.07.13 02:30:45.342422 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_6ne5hpqi.sql.tmp 2025.07.13 02:30:45.342480 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_revqyt6n.sql.tmp 2025.07.13 02:30:45.342554 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_qukcu8wg.sql.tmp 2025.07.13 02:30:45.342607 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_uirpaokr.sql.tmp 2025.07.13 02:30:45.342683 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_pgprnl4b.sql.tmp 2025.07.13 02:30:45.342735 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_v8498esk.sql.tmp 2025.07.13 02:30:45.342835 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_c4ny5fzq.sql.tmp 2025.07.13 02:30:45.342883 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_1cdq7in2.sql.tmp 2025.07.13 02:30:45.343002 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_hkey001m.sql.tmp 2025.07.13 02:30:45.343060 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_u3c2nmtp.sql.tmp 2025.07.13 02:30:45.343110 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_nv9krm2l.sql.tmp 2025.07.13 02:30:45.343165 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_c4u2o8g9.sql.tmp 2025.07.13 02:30:45.343221 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_86ev5sij.sql.tmp 2025.07.13 02:30:45.343270 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_gxfziybw.sql.tmp 2025.07.13 02:30:45.343336 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_u0m3t8x9.sql.tmp 2025.07.13 02:30:45.343388 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_oxkeue3n.sql.tmp 2025.07.13 02:30:45.343447 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_hv7rgdhw.sql.tmp 2025.07.13 02:30:45.343495 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_njqqbqsn.sql.tmp 2025.07.13 02:30:45.343575 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_8o2yw30n.sql.tmp 2025.07.13 02:30:45.343626 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_livqfl2q.sql.tmp 2025.07.13 02:30:45.343679 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_tneylht2.sql.tmp 2025.07.13 02:30:45.343738 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_pp3b7j8w.sql.tmp 2025.07.13 02:30:45.343785 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_ivwczfwz.sql.tmp 2025.07.13 02:30:45.343831 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_rgvyp2m5.sql.tmp 2025.07.13 02:30:45.343877 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_e3wzcn3x.sql.tmp 2025.07.13 02:30:45.343926 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_e32rcraf.sql.tmp 2025.07.13 02:30:45.343971 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_fujw2fll.sql.tmp 2025.07.13 02:30:45.344015 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_9yxsqxxb.sql.tmp 2025.07.13 02:30:45.344071 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_718pxt3b.sql.tmp 2025.07.13 02:30:45.344119 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_5j2r1aih.sql.tmp 2025.07.13 02:30:45.344184 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_0wa1fcar.sql.tmp 2025.07.13 02:30:45.344257 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_j3odyil6.sql.tmp 2025.07.13 02:30:45.344303 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_k0p79q4t.sql.tmp 2025.07.13 02:30:45.344351 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_xdn80ppf.sql.tmp 2025.07.13 02:30:45.344396 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_ze1nwnjj.sql.tmp 2025.07.13 02:30:45.344442 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_nyj5kagw.sql.tmp 2025.07.13 02:30:45.344488 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_t8fjynxn.sql.tmp 2025.07.13 02:30:45.356316 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_5mmvzs7z.sql.tmp 2025.07.13 02:30:45.356415 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test.sql.tmp 2025.07.13 02:30:45.356470 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_qd4rul31.sql.tmp 2025.07.13 02:30:45.356783 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_nze80w29.sql.tmp 2025.07.13 02:30:45.356842 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_3ki1dtsx.sql.tmp 2025.07.13 02:30:45.356890 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_rlgp5mjp.sql.tmp 2025.07.13 02:30:45.356936 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_e7j7tuqm.sql.tmp 2025.07.13 02:30:45.356990 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_q7wj7r0k.sql.tmp 2025.07.13 02:30:45.357044 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_0gsr3sh6.sql.tmp 2025.07.13 02:30:45.357102 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_dajzi9jc.sql.tmp 2025.07.13 02:30:45.357163 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_8huflzim.sql.tmp 2025.07.13 02:30:45.357210 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_55hytmo2.sql.tmp 2025.07.13 02:30:45.357268 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_30vrf7q5.sql.tmp 2025.07.13 02:30:45.357313 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_ip4o8k9s.sql.tmp 2025.07.13 02:30:45.357358 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_9p48p34t.sql.tmp 2025.07.13 02:30:45.357402 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_i6rclhby.sql.tmp 2025.07.13 02:30:45.357448 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_jsz9pzwz.sql.tmp 2025.07.13 02:30:45.357513 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_0rz6wkhc.sql.tmp 2025.07.13 02:30:45.357594 [ 56926 ] {} loadMetadata: Removing temporary file metadata/test_8mkl6m6h.sql.tmp 2025.07.13 02:30:45.520969 [ 56926 ] {} TablesLoader: Tables test_3.dist_test_01040 depend on default.key, but seems like that does not exist. Will ignore it and try to load existing tables 2025.07.13 02:30:45.521075 [ 56926 ] {} TablesLoader: Tables test_5.test_dictionary_10_shards_incremental depend on test_5.test_table_last_access, but seems like that does not exist. Will ignore it and try to load existing tables 2025.07.13 02:30:45.978200 [ 57868 ] {} test_3.table_one (a0a86c7f-a683-462f-9a92-29220c16e2eb): 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:30:46.347513 [ 57871 ] {} DDLWorker(test_a5n6ct77): Replica seems to be lost: our_log_ptr=8, max_log_ptr=8, local_digest=18215305118721058763, zk_digest=15265212596422884256 2025.07.13 02:30:46.347819 [ 57871 ] {} DatabaseReplicated (test_a5n6ct77): Will recover replica with staled log pointer 8 from log pointer 8 2025.07.13 02:30:56.942057 [ 57528 ] {} RaftInstance: failed to accept a rpc connection due to error 125, Operation canceled 2025.07.13 02:31:06.695511 [ 58230 ] {} DiskLocal: Cannot gain read access of the disk directory: disk1_02961/ 2025.07.13 02:31:06.999445 [ 58230 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x000000000fb69775 4. /build/src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x000000000fb695a2 5. /build/src/Common/filesystemHelpers.cpp:324: ? @ 0x000000000fb70b4f 6. /build/src/Disks/DiskLocal.cpp:680: DB::DiskLocal::setup() @ 0x0000000013ddaf00 7. /build/src/Disks/DiskLocal.cpp:752: DB::DiskLocal::startupImpl(std::shared_ptr) @ 0x0000000013ddbdd1 8. /build/src/Disks/IDisk.cpp:212: DB::IDisk::startup(std::shared_ptr, bool) @ 0x0000000013de41ee 9. /build/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:se190107] (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) @ 0x0000000013ddc6b5 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013dce296 11. /build/src/Disks/DiskSelector.cpp:55: DB::DiskSelector::initialize(Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::function) @ 0x0000000013df13f1 12. /build/src/Interpreters/Context.cpp:5058: DB::Context::getDiskSelector(std::lock_guard&) const @ 0x000000001436660e 13. /build/src/Interpreters/Context.cpp:5042: DB::Context::getDisksMap(std::lock_guard&) const @ 0x0000000014366916 14. /build/src/Interpreters/Context.cpp:5037: DB::Context::getDatabaseDisk() const @ 0x00000000143448b6 15. /build/src/Databases/DatabasesCommon.cpp:329: DB::DatabaseWithOwnTablesBase::DatabaseWithOwnTablesBase(String const&, String const&, std::shared_ptr) @ 0x0000000013cf09c6 16. /build/src/Databases/DatabaseMemory.cpp:24: DB::DatabaseMemory::DatabaseMemory(String const&, std::shared_ptr) @ 0x0000000013c8ae87 17. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], char const* const&, std::shared_ptr, 0>(std::allocator const&, char const* const&, std::shared_ptr&&) @ 0x000000001442c17f 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::DatabaseCatalog::initializeAndLoadTemporaryDatabase() @ 0x00000000144124ec 19. /build/programs/local/LocalServer.cpp:859: DB::LocalServer::processConfig() @ 0x000000000fd518e6 20. /build/programs/local/LocalServer.cpp:583: DB::LocalServer::main(std::vector> const&) @ 0x000000000fd4d43c 21. /build/base/poco/Util/src/Application.cpp:315: Poco::Util::Application::run() @ 0x000000001aba9e26 22. /build/programs/local/LocalServer.cpp:1088: mainEntryClickHouseLocal(int, char**) @ 0x000000000fd5887c 23. /build/programs/main.cpp:295: main @ 0x0000000009fa7c8a 24. ? @ 0x00007f8f9633fd90 25. ? @ 0x00007f8f9633fe40 26. _start @ 0x0000000009fa702e (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:06.999863 [ 58230 ] {} DiskLocal: Cannot gain read access of the disk directory: disk2_02961/ 2025.07.13 02:31:06.999929 [ 58230 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x000000000fb69775 4. /build/src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x000000000fb695a2 5. /build/src/Common/filesystemHelpers.cpp:324: ? @ 0x000000000fb70b4f 6. /build/src/Disks/DiskLocal.cpp:680: DB::DiskLocal::setup() @ 0x0000000013ddaf00 7. /build/src/Disks/DiskLocal.cpp:752: DB::DiskLocal::startupImpl(std::shared_ptr) @ 0x0000000013ddbdd1 8. /build/src/Disks/IDisk.cpp:212: DB::IDisk::startup(std::shared_ptr, bool) @ 0x0000000013de41ee 9. /build/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:se190107] (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) @ 0x0000000013ddc6b5 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013dce296 11. /build/src/Disks/DiskSelector.cpp:55: DB::DiskSelector::initialize(Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::function) @ 0x0000000013df13f1 12. /build/src/Interpreters/Context.cpp:5058: DB::Context::getDiskSelector(std::lock_guard&) const @ 0x000000001436660e 13. /build/src/Interpreters/Context.cpp:5042: DB::Context::getDisksMap(std::lock_guard&) const @ 0x0000000014366916 14. /build/src/Interpreters/Context.cpp:5037: DB::Context::getDatabaseDisk() const @ 0x00000000143448b6 15. /build/src/Databases/DatabasesCommon.cpp:329: DB::DatabaseWithOwnTablesBase::DatabaseWithOwnTablesBase(String const&, String const&, std::shared_ptr) @ 0x0000000013cf09c6 16. /build/src/Databases/DatabaseMemory.cpp:24: DB::DatabaseMemory::DatabaseMemory(String const&, std::shared_ptr) @ 0x0000000013c8ae87 17. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], char const* const&, std::shared_ptr, 0>(std::allocator const&, char const* const&, std::shared_ptr&&) @ 0x000000001442c17f 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::DatabaseCatalog::initializeAndLoadTemporaryDatabase() @ 0x00000000144124ec 19. /build/programs/local/LocalServer.cpp:859: DB::LocalServer::processConfig() @ 0x000000000fd518e6 20. /build/programs/local/LocalServer.cpp:583: DB::LocalServer::main(std::vector> const&) @ 0x000000000fd4d43c 21. /build/base/poco/Util/src/Application.cpp:315: Poco::Util::Application::run() @ 0x000000001aba9e26 22. /build/programs/local/LocalServer.cpp:1088: mainEntryClickHouseLocal(int, char**) @ 0x000000000fd5887c 23. /build/programs/main.cpp:295: main @ 0x0000000009fa7c8a 24. ? @ 0x00007f8f9633fd90 25. ? @ 0x00007f8f9633fe40 26. _start @ 0x0000000009fa702e (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:07.000098 [ 58230 ] {} DiskLocal: Cannot gain read access of the disk directory: disk3_02961/ 2025.07.13 02:31:07.000164 [ 58230 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x000000000fb69775 4. /build/src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x000000000fb695a2 5. /build/src/Common/filesystemHelpers.cpp:324: ? @ 0x000000000fb70b4f 6. /build/src/Disks/DiskLocal.cpp:680: DB::DiskLocal::setup() @ 0x0000000013ddaf00 7. /build/src/Disks/DiskLocal.cpp:752: DB::DiskLocal::startupImpl(std::shared_ptr) @ 0x0000000013ddbdd1 8. /build/src/Disks/IDisk.cpp:212: DB::IDisk::startup(std::shared_ptr, bool) @ 0x0000000013de41ee 9. /build/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:se190107] (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) @ 0x0000000013ddc6b5 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013dce296 11. /build/src/Disks/DiskSelector.cpp:55: DB::DiskSelector::initialize(Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::function) @ 0x0000000013df13f1 12. /build/src/Interpreters/Context.cpp:5058: DB::Context::getDiskSelector(std::lock_guard&) const @ 0x000000001436660e 13. /build/src/Interpreters/Context.cpp:5042: DB::Context::getDisksMap(std::lock_guard&) const @ 0x0000000014366916 14. /build/src/Interpreters/Context.cpp:5037: DB::Context::getDatabaseDisk() const @ 0x00000000143448b6 15. /build/src/Databases/DatabasesCommon.cpp:329: DB::DatabaseWithOwnTablesBase::DatabaseWithOwnTablesBase(String const&, String const&, std::shared_ptr) @ 0x0000000013cf09c6 16. /build/src/Databases/DatabaseMemory.cpp:24: DB::DatabaseMemory::DatabaseMemory(String const&, std::shared_ptr) @ 0x0000000013c8ae87 17. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], char const* const&, std::shared_ptr, 0>(std::allocator const&, char const* const&, std::shared_ptr&&) @ 0x000000001442c17f 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::DatabaseCatalog::initializeAndLoadTemporaryDatabase() @ 0x00000000144124ec 19. /build/programs/local/LocalServer.cpp:859: DB::LocalServer::processConfig() @ 0x000000000fd518e6 20. /build/programs/local/LocalServer.cpp:583: DB::LocalServer::main(std::vector> const&) @ 0x000000000fd4d43c 21. /build/base/poco/Util/src/Application.cpp:315: Poco::Util::Application::run() @ 0x000000001aba9e26 22. /build/programs/local/LocalServer.cpp:1088: mainEntryClickHouseLocal(int, char**) @ 0x000000000fd5887c 23. /build/programs/main.cpp:295: main @ 0x0000000009fa7c8a 24. ? @ 0x00007f8f9633fd90 25. ? @ 0x00007f8f9633fe40 26. _start @ 0x0000000009fa702e (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:07.000334 [ 58230 ] {} DiskLocal: Cannot gain read access of the disk directory: disk4_02961/ 2025.07.13 02:31:07.000390 [ 58230 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x000000000fb69775 4. /build/src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x000000000fb695a2 5. /build/src/Common/filesystemHelpers.cpp:324: ? @ 0x000000000fb70b4f 6. /build/src/Disks/DiskLocal.cpp:680: DB::DiskLocal::setup() @ 0x0000000013ddaf00 7. /build/src/Disks/DiskLocal.cpp:752: DB::DiskLocal::startupImpl(std::shared_ptr) @ 0x0000000013ddbdd1 8. /build/src/Disks/IDisk.cpp:212: DB::IDisk::startup(std::shared_ptr, bool) @ 0x0000000013de41ee 9. /build/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:se190107] (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) @ 0x0000000013ddc6b5 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013dce296 11. /build/src/Disks/DiskSelector.cpp:55: DB::DiskSelector::initialize(Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::function) @ 0x0000000013df13f1 12. /build/src/Interpreters/Context.cpp:5058: DB::Context::getDiskSelector(std::lock_guard&) const @ 0x000000001436660e 13. /build/src/Interpreters/Context.cpp:5042: DB::Context::getDisksMap(std::lock_guard&) const @ 0x0000000014366916 14. /build/src/Interpreters/Context.cpp:5037: DB::Context::getDatabaseDisk() const @ 0x00000000143448b6 15. /build/src/Databases/DatabasesCommon.cpp:329: DB::DatabaseWithOwnTablesBase::DatabaseWithOwnTablesBase(String const&, String const&, std::shared_ptr) @ 0x0000000013cf09c6 16. /build/src/Databases/DatabaseMemory.cpp:24: DB::DatabaseMemory::DatabaseMemory(String const&, std::shared_ptr) @ 0x0000000013c8ae87 17. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], char const* const&, std::shared_ptr, 0>(std::allocator const&, char const* const&, std::shared_ptr&&) @ 0x000000001442c17f 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::DatabaseCatalog::initializeAndLoadTemporaryDatabase() @ 0x00000000144124ec 19. /build/programs/local/LocalServer.cpp:859: DB::LocalServer::processConfig() @ 0x000000000fd518e6 20. /build/programs/local/LocalServer.cpp:583: DB::LocalServer::main(std::vector> const&) @ 0x000000000fd4d43c 21. /build/base/poco/Util/src/Application.cpp:315: Poco::Util::Application::run() @ 0x000000001aba9e26 22. /build/programs/local/LocalServer.cpp:1088: mainEntryClickHouseLocal(int, char**) @ 0x000000000fd5887c 23. /build/programs/main.cpp:295: main @ 0x0000000009fa7c8a 24. ? @ 0x00007f8f9633fd90 25. ? @ 0x00007f8f9633fe40 26. _start @ 0x0000000009fa702e (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:18.937104 [ 58958 ] {} DiskLocal: Cannot gain read access of the disk directory: disk1_02961/ 2025.07.13 02:31:19.245786 [ 58958 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x000000000fb69775 4. /build/src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x000000000fb695a2 5. /build/src/Common/filesystemHelpers.cpp:324: ? @ 0x000000000fb70b4f 6. /build/src/Disks/DiskLocal.cpp:680: DB::DiskLocal::setup() @ 0x0000000013ddaf00 7. /build/src/Disks/DiskLocal.cpp:752: DB::DiskLocal::startupImpl(std::shared_ptr) @ 0x0000000013ddbdd1 8. /build/src/Disks/IDisk.cpp:212: DB::IDisk::startup(std::shared_ptr, bool) @ 0x0000000013de41ee 9. /build/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:se190107] (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) @ 0x0000000013ddc6b5 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013dce296 11. /build/src/Disks/DiskSelector.cpp:55: DB::DiskSelector::initialize(Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::function) @ 0x0000000013df13f1 12. /build/src/Interpreters/Context.cpp:5058: DB::Context::getDiskSelector(std::lock_guard&) const @ 0x000000001436660e 13. /build/src/Interpreters/Context.cpp:5042: DB::Context::getDisksMap(std::lock_guard&) const @ 0x0000000014366916 14. /build/src/Interpreters/Context.cpp:5037: DB::Context::getDatabaseDisk() const @ 0x00000000143448b6 15. /build/src/Databases/DatabasesCommon.cpp:329: DB::DatabaseWithOwnTablesBase::DatabaseWithOwnTablesBase(String const&, String const&, std::shared_ptr) @ 0x0000000013cf09c6 16. /build/src/Databases/DatabaseMemory.cpp:24: DB::DatabaseMemory::DatabaseMemory(String const&, std::shared_ptr) @ 0x0000000013c8ae87 17. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], char const* const&, std::shared_ptr, 0>(std::allocator const&, char const* const&, std::shared_ptr&&) @ 0x000000001442c17f 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::DatabaseCatalog::initializeAndLoadTemporaryDatabase() @ 0x00000000144124ec 19. /build/programs/local/LocalServer.cpp:859: DB::LocalServer::processConfig() @ 0x000000000fd518e6 20. /build/programs/local/LocalServer.cpp:583: DB::LocalServer::main(std::vector> const&) @ 0x000000000fd4d43c 21. /build/base/poco/Util/src/Application.cpp:315: Poco::Util::Application::run() @ 0x000000001aba9e26 22. /build/programs/local/LocalServer.cpp:1088: mainEntryClickHouseLocal(int, char**) @ 0x000000000fd5887c 23. /build/programs/main.cpp:295: main @ 0x0000000009fa7c8a 24. ? @ 0x00007fecc3a64d90 25. ? @ 0x00007fecc3a64e40 26. _start @ 0x0000000009fa702e (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:19.246157 [ 58958 ] {} DiskLocal: Cannot gain read access of the disk directory: disk2_02961/ 2025.07.13 02:31:19.246222 [ 58958 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x000000000fb69775 4. /build/src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x000000000fb695a2 5. /build/src/Common/filesystemHelpers.cpp:324: ? @ 0x000000000fb70b4f 6. /build/src/Disks/DiskLocal.cpp:680: DB::DiskLocal::setup() @ 0x0000000013ddaf00 7. /build/src/Disks/DiskLocal.cpp:752: DB::DiskLocal::startupImpl(std::shared_ptr) @ 0x0000000013ddbdd1 8. /build/src/Disks/IDisk.cpp:212: DB::IDisk::startup(std::shared_ptr, bool) @ 0x0000000013de41ee 9. /build/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:se190107] (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) @ 0x0000000013ddc6b5 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013dce296 11. /build/src/Disks/DiskSelector.cpp:55: DB::DiskSelector::initialize(Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::function) @ 0x0000000013df13f1 12. /build/src/Interpreters/Context.cpp:5058: DB::Context::getDiskSelector(std::lock_guard&) const @ 0x000000001436660e 13. /build/src/Interpreters/Context.cpp:5042: DB::Context::getDisksMap(std::lock_guard&) const @ 0x0000000014366916 14. /build/src/Interpreters/Context.cpp:5037: DB::Context::getDatabaseDisk() const @ 0x00000000143448b6 15. /build/src/Databases/DatabasesCommon.cpp:329: DB::DatabaseWithOwnTablesBase::DatabaseWithOwnTablesBase(String const&, String const&, std::shared_ptr) @ 0x0000000013cf09c6 16. /build/src/Databases/DatabaseMemory.cpp:24: DB::DatabaseMemory::DatabaseMemory(String const&, std::shared_ptr) @ 0x0000000013c8ae87 17. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], char const* const&, std::shared_ptr, 0>(std::allocator const&, char const* const&, std::shared_ptr&&) @ 0x000000001442c17f 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::DatabaseCatalog::initializeAndLoadTemporaryDatabase() @ 0x00000000144124ec 19. /build/programs/local/LocalServer.cpp:859: DB::LocalServer::processConfig() @ 0x000000000fd518e6 20. /build/programs/local/LocalServer.cpp:583: DB::LocalServer::main(std::vector> const&) @ 0x000000000fd4d43c 21. /build/base/poco/Util/src/Application.cpp:315: Poco::Util::Application::run() @ 0x000000001aba9e26 22. /build/programs/local/LocalServer.cpp:1088: mainEntryClickHouseLocal(int, char**) @ 0x000000000fd5887c 23. /build/programs/main.cpp:295: main @ 0x0000000009fa7c8a 24. ? @ 0x00007fecc3a64d90 25. ? @ 0x00007fecc3a64e40 26. _start @ 0x0000000009fa702e (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:19.246395 [ 58958 ] {} DiskLocal: Cannot gain read access of the disk directory: disk3_02961/ 2025.07.13 02:31:19.246451 [ 58958 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x000000000fb69775 4. /build/src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x000000000fb695a2 5. /build/src/Common/filesystemHelpers.cpp:324: ? @ 0x000000000fb70b4f 6. /build/src/Disks/DiskLocal.cpp:680: DB::DiskLocal::setup() @ 0x0000000013ddaf00 7. /build/src/Disks/DiskLocal.cpp:752: DB::DiskLocal::startupImpl(std::shared_ptr) @ 0x0000000013ddbdd1 8. /build/src/Disks/IDisk.cpp:212: DB::IDisk::startup(std::shared_ptr, bool) @ 0x0000000013de41ee 9. /build/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:se190107] (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) @ 0x0000000013ddc6b5 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013dce296 11. /build/src/Disks/DiskSelector.cpp:55: DB::DiskSelector::initialize(Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::function) @ 0x0000000013df13f1 12. /build/src/Interpreters/Context.cpp:5058: DB::Context::getDiskSelector(std::lock_guard&) const @ 0x000000001436660e 13. /build/src/Interpreters/Context.cpp:5042: DB::Context::getDisksMap(std::lock_guard&) const @ 0x0000000014366916 14. /build/src/Interpreters/Context.cpp:5037: DB::Context::getDatabaseDisk() const @ 0x00000000143448b6 15. /build/src/Databases/DatabasesCommon.cpp:329: DB::DatabaseWithOwnTablesBase::DatabaseWithOwnTablesBase(String const&, String const&, std::shared_ptr) @ 0x0000000013cf09c6 16. /build/src/Databases/DatabaseMemory.cpp:24: DB::DatabaseMemory::DatabaseMemory(String const&, std::shared_ptr) @ 0x0000000013c8ae87 17. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], char const* const&, std::shared_ptr, 0>(std::allocator const&, char const* const&, std::shared_ptr&&) @ 0x000000001442c17f 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::DatabaseCatalog::initializeAndLoadTemporaryDatabase() @ 0x00000000144124ec 19. /build/programs/local/LocalServer.cpp:859: DB::LocalServer::processConfig() @ 0x000000000fd518e6 20. /build/programs/local/LocalServer.cpp:583: DB::LocalServer::main(std::vector> const&) @ 0x000000000fd4d43c 21. /build/base/poco/Util/src/Application.cpp:315: Poco::Util::Application::run() @ 0x000000001aba9e26 22. /build/programs/local/LocalServer.cpp:1088: mainEntryClickHouseLocal(int, char**) @ 0x000000000fd5887c 23. /build/programs/main.cpp:295: main @ 0x0000000009fa7c8a 24. ? @ 0x00007fecc3a64d90 25. ? @ 0x00007fecc3a64e40 26. _start @ 0x0000000009fa702e (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:19.246830 [ 58958 ] {} DiskLocal: Cannot gain read access of the disk directory: disk4_02961/ 2025.07.13 02:31:19.246887 [ 58958 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x000000000fb69775 4. /build/src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x000000000fb695a2 5. /build/src/Common/filesystemHelpers.cpp:324: ? @ 0x000000000fb70b4f 6. /build/src/Disks/DiskLocal.cpp:680: DB::DiskLocal::setup() @ 0x0000000013ddaf00 7. /build/src/Disks/DiskLocal.cpp:752: DB::DiskLocal::startupImpl(std::shared_ptr) @ 0x0000000013ddbdd1 8. /build/src/Disks/IDisk.cpp:212: DB::IDisk::startup(std::shared_ptr, bool) @ 0x0000000013de41ee 9. /build/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:se190107] (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) @ 0x0000000013ddc6b5 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013dce296 11. /build/src/Disks/DiskSelector.cpp:55: DB::DiskSelector::initialize(Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::function) @ 0x0000000013df13f1 12. /build/src/Interpreters/Context.cpp:5058: DB::Context::getDiskSelector(std::lock_guard&) const @ 0x000000001436660e 13. /build/src/Interpreters/Context.cpp:5042: DB::Context::getDisksMap(std::lock_guard&) const @ 0x0000000014366916 14. /build/src/Interpreters/Context.cpp:5037: DB::Context::getDatabaseDisk() const @ 0x00000000143448b6 15. /build/src/Databases/DatabasesCommon.cpp:329: DB::DatabaseWithOwnTablesBase::DatabaseWithOwnTablesBase(String const&, String const&, std::shared_ptr) @ 0x0000000013cf09c6 16. /build/src/Databases/DatabaseMemory.cpp:24: DB::DatabaseMemory::DatabaseMemory(String const&, std::shared_ptr) @ 0x0000000013c8ae87 17. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], char const* const&, std::shared_ptr, 0>(std::allocator const&, char const* const&, std::shared_ptr&&) @ 0x000000001442c17f 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::DatabaseCatalog::initializeAndLoadTemporaryDatabase() @ 0x00000000144124ec 19. /build/programs/local/LocalServer.cpp:859: DB::LocalServer::processConfig() @ 0x000000000fd518e6 20. /build/programs/local/LocalServer.cpp:583: DB::LocalServer::main(std::vector> const&) @ 0x000000000fd4d43c 21. /build/base/poco/Util/src/Application.cpp:315: Poco::Util::Application::run() @ 0x000000001aba9e26 22. /build/programs/local/LocalServer.cpp:1088: mainEntryClickHouseLocal(int, char**) @ 0x000000000fd5887c 23. /build/programs/main.cpp:295: main @ 0x0000000009fa7c8a 24. ? @ 0x00007fecc3a64d90 25. ? @ 0x00007fecc3a64e40 26. _start @ 0x0000000009fa702e (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:37.502711 [ 59734 ] {} DiskLocal: Cannot gain read access of the disk directory: disk1_02961/ 2025.07.13 02:31:37.801069 [ 59734 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x000000000fb69775 4. /build/src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x000000000fb695a2 5. /build/src/Common/filesystemHelpers.cpp:324: ? @ 0x000000000fb70b4f 6. /build/src/Disks/DiskLocal.cpp:680: DB::DiskLocal::setup() @ 0x0000000013ddaf00 7. /build/src/Disks/DiskLocal.cpp:752: DB::DiskLocal::startupImpl(std::shared_ptr) @ 0x0000000013ddbdd1 8. /build/src/Disks/IDisk.cpp:212: DB::IDisk::startup(std::shared_ptr, bool) @ 0x0000000013de41ee 9. /build/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:se190107] (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) @ 0x0000000013ddc6b5 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013dce296 11. /build/src/Disks/DiskSelector.cpp:55: DB::DiskSelector::initialize(Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::function) @ 0x0000000013df13f1 12. /build/src/Interpreters/Context.cpp:5058: DB::Context::getDiskSelector(std::lock_guard&) const @ 0x000000001436660e 13. /build/src/Interpreters/Context.cpp:5042: DB::Context::getDisksMap(std::lock_guard&) const @ 0x0000000014366916 14. /build/src/Interpreters/Context.cpp:5037: DB::Context::getDatabaseDisk() const @ 0x00000000143448b6 15. /build/src/Databases/DatabasesCommon.cpp:329: DB::DatabaseWithOwnTablesBase::DatabaseWithOwnTablesBase(String const&, String const&, std::shared_ptr) @ 0x0000000013cf09c6 16. /build/src/Databases/DatabaseMemory.cpp:24: DB::DatabaseMemory::DatabaseMemory(String const&, std::shared_ptr) @ 0x0000000013c8ae87 17. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], char const* const&, std::shared_ptr, 0>(std::allocator const&, char const* const&, std::shared_ptr&&) @ 0x000000001442c17f 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::DatabaseCatalog::initializeAndLoadTemporaryDatabase() @ 0x00000000144124ec 19. /build/programs/local/LocalServer.cpp:859: DB::LocalServer::processConfig() @ 0x000000000fd518e6 20. /build/programs/local/LocalServer.cpp:583: DB::LocalServer::main(std::vector> const&) @ 0x000000000fd4d43c 21. /build/base/poco/Util/src/Application.cpp:315: Poco::Util::Application::run() @ 0x000000001aba9e26 22. /build/programs/local/LocalServer.cpp:1088: mainEntryClickHouseLocal(int, char**) @ 0x000000000fd5887c 23. /build/programs/main.cpp:295: main @ 0x0000000009fa7c8a 24. ? @ 0x00007f4a72dafd90 25. ? @ 0x00007f4a72dafe40 26. _start @ 0x0000000009fa702e (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:37.801587 [ 59734 ] {} DiskLocal: Cannot gain read access of the disk directory: disk2_02961/ 2025.07.13 02:31:37.801656 [ 59734 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x000000000fb69775 4. /build/src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x000000000fb695a2 5. /build/src/Common/filesystemHelpers.cpp:324: ? @ 0x000000000fb70b4f 6. /build/src/Disks/DiskLocal.cpp:680: DB::DiskLocal::setup() @ 0x0000000013ddaf00 7. /build/src/Disks/DiskLocal.cpp:752: DB::DiskLocal::startupImpl(std::shared_ptr) @ 0x0000000013ddbdd1 8. /build/src/Disks/IDisk.cpp:212: DB::IDisk::startup(std::shared_ptr, bool) @ 0x0000000013de41ee 9. /build/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:se190107] (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) @ 0x0000000013ddc6b5 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013dce296 11. /build/src/Disks/DiskSelector.cpp:55: DB::DiskSelector::initialize(Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::function) @ 0x0000000013df13f1 12. /build/src/Interpreters/Context.cpp:5058: DB::Context::getDiskSelector(std::lock_guard&) const @ 0x000000001436660e 13. /build/src/Interpreters/Context.cpp:5042: DB::Context::getDisksMap(std::lock_guard&) const @ 0x0000000014366916 14. /build/src/Interpreters/Context.cpp:5037: DB::Context::getDatabaseDisk() const @ 0x00000000143448b6 15. /build/src/Databases/DatabasesCommon.cpp:329: DB::DatabaseWithOwnTablesBase::DatabaseWithOwnTablesBase(String const&, String const&, std::shared_ptr) @ 0x0000000013cf09c6 16. /build/src/Databases/DatabaseMemory.cpp:24: DB::DatabaseMemory::DatabaseMemory(String const&, std::shared_ptr) @ 0x0000000013c8ae87 17. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], char const* const&, std::shared_ptr, 0>(std::allocator const&, char const* const&, std::shared_ptr&&) @ 0x000000001442c17f 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::DatabaseCatalog::initializeAndLoadTemporaryDatabase() @ 0x00000000144124ec 19. /build/programs/local/LocalServer.cpp:859: DB::LocalServer::processConfig() @ 0x000000000fd518e6 20. /build/programs/local/LocalServer.cpp:583: DB::LocalServer::main(std::vector> const&) @ 0x000000000fd4d43c 21. /build/base/poco/Util/src/Application.cpp:315: Poco::Util::Application::run() @ 0x000000001aba9e26 22. /build/programs/local/LocalServer.cpp:1088: mainEntryClickHouseLocal(int, char**) @ 0x000000000fd5887c 23. /build/programs/main.cpp:295: main @ 0x0000000009fa7c8a 24. ? @ 0x00007f4a72dafd90 25. ? @ 0x00007f4a72dafe40 26. _start @ 0x0000000009fa702e (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:37.801828 [ 59734 ] {} DiskLocal: Cannot gain read access of the disk directory: disk3_02961/ 2025.07.13 02:31:37.801883 [ 59734 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x000000000fb69775 4. /build/src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x000000000fb695a2 5. /build/src/Common/filesystemHelpers.cpp:324: ? @ 0x000000000fb70b4f 6. /build/src/Disks/DiskLocal.cpp:680: DB::DiskLocal::setup() @ 0x0000000013ddaf00 7. /build/src/Disks/DiskLocal.cpp:752: DB::DiskLocal::startupImpl(std::shared_ptr) @ 0x0000000013ddbdd1 8. /build/src/Disks/IDisk.cpp:212: DB::IDisk::startup(std::shared_ptr, bool) @ 0x0000000013de41ee 9. /build/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:se190107] (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) @ 0x0000000013ddc6b5 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013dce296 11. /build/src/Disks/DiskSelector.cpp:55: DB::DiskSelector::initialize(Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::function) @ 0x0000000013df13f1 12. /build/src/Interpreters/Context.cpp:5058: DB::Context::getDiskSelector(std::lock_guard&) const @ 0x000000001436660e 13. /build/src/Interpreters/Context.cpp:5042: DB::Context::getDisksMap(std::lock_guard&) const @ 0x0000000014366916 14. /build/src/Interpreters/Context.cpp:5037: DB::Context::getDatabaseDisk() const @ 0x00000000143448b6 15. /build/src/Databases/DatabasesCommon.cpp:329: DB::DatabaseWithOwnTablesBase::DatabaseWithOwnTablesBase(String const&, String const&, std::shared_ptr) @ 0x0000000013cf09c6 16. /build/src/Databases/DatabaseMemory.cpp:24: DB::DatabaseMemory::DatabaseMemory(String const&, std::shared_ptr) @ 0x0000000013c8ae87 17. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], char const* const&, std::shared_ptr, 0>(std::allocator const&, char const* const&, std::shared_ptr&&) @ 0x000000001442c17f 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::DatabaseCatalog::initializeAndLoadTemporaryDatabase() @ 0x00000000144124ec 19. /build/programs/local/LocalServer.cpp:859: DB::LocalServer::processConfig() @ 0x000000000fd518e6 20. /build/programs/local/LocalServer.cpp:583: DB::LocalServer::main(std::vector> const&) @ 0x000000000fd4d43c 21. /build/base/poco/Util/src/Application.cpp:315: Poco::Util::Application::run() @ 0x000000001aba9e26 22. /build/programs/local/LocalServer.cpp:1088: mainEntryClickHouseLocal(int, char**) @ 0x000000000fd5887c 23. /build/programs/main.cpp:295: main @ 0x0000000009fa7c8a 24. ? @ 0x00007f4a72dafd90 25. ? @ 0x00007f4a72dafe40 26. _start @ 0x0000000009fa702e (version 25.3.3.20372.altinityantalya (altinity build)) 2025.07.13 02:31:37.802041 [ 59734 ] {} DiskLocal: Cannot gain read access of the disk directory: disk4_02961/ 2025.07.13 02:31:37.802096 [ 59734 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001aae8472 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fac0e99 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000009faf88c 3. /build/src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x000000000fb69775 4. /build/src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x000000000fb695a2 5. /build/src/Common/filesystemHelpers.cpp:324: ? @ 0x000000000fb70b4f 6. /build/src/Disks/DiskLocal.cpp:680: DB::DiskLocal::setup() @ 0x0000000013ddaf00 7. /build/src/Disks/DiskLocal.cpp:752: DB::DiskLocal::startupImpl(std::shared_ptr) @ 0x0000000013ddbdd1 8. /build/src/Disks/IDisk.cpp:212: DB::IDisk::startup(std::shared_ptr, bool) @ 0x0000000013de41ee 9. /build/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:se190107] (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) @ 0x0000000013ddc6b5 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013dce296 11. /build/src/Disks/DiskSelector.cpp:55: DB::DiskSelector::initialize(Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::function) @ 0x0000000013df13f1 12. /build/src/Interpreters/Context.cpp:5058: DB::Context::getDiskSelector(std::lock_guard&) const @ 0x000000001436660e 13. /build/src/Interpreters/Context.cpp:5042: DB::Context::getDisksMap(std::lock_guard&) const @ 0x0000000014366916 14. /build/src/Interpreters/Context.cpp:5037: DB::Context::getDatabaseDisk() const @ 0x00000000143448b6 15. /build/src/Databases/DatabasesCommon.cpp:329: DB::DatabaseWithOwnTablesBase::DatabaseWithOwnTablesBase(String const&, String const&, std::shared_ptr) @ 0x0000000013cf09c6 16. /build/src/Databases/DatabaseMemory.cpp:24: DB::DatabaseMemory::DatabaseMemory(String const&, std::shared_ptr) @ 0x0000000013c8ae87 17. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], char const* const&, std::shared_ptr, 0>(std::allocator const&, char const* const&, std::shared_ptr&&) @ 0x000000001442c17f 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::DatabaseCatalog::initializeAndLoadTemporaryDatabase() @ 0x00000000144124ec 19. /build/programs/local/LocalServer.cpp:859: DB::LocalServer::processConfig() @ 0x000000000fd518e6 20. /build/programs/local/LocalServer.cpp:583: DB::LocalServer::main(std::vector> const&) @ 0x000000000fd4d43c 21. /build/base/poco/Util/src/Application.cpp:315: Poco::Util::Application::run() @ 0x000000001aba9e26 22. /build/programs/local/LocalServer.cpp:1088: mainEntryClickHouseLocal(int, char**) @ 0x000000000fd5887c 23. /build/programs/main.cpp:295: main @ 0x0000000009fa7c8a 24. ? @ 0x00007f4a72dafd90 25. ? @ 0x00007f4a72dafe40 26. _start @ 0x0000000009fa702e (version 25.3.3.20372.altinityantalya (altinity build))